2025.07.13 02:14:57.035359 [ 416 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.13 02:14:57.036297 [ 416 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.07.13 02:14:57.829573 [ 422 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 02:14:59.590455 [ 416 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.07.13 02:14:59.593239 [ 416 ] {} KeeperLogStore: Removing all changelogs 2025.07.13 02:14:59.599458 [ 416 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.13 02:14:59.616503 [ 416 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 02:14:59.616894 [ 416 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 02:14:59.676041 [ 1010 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 02:15:00.194039 [ 416 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.07.13 02:15:00.194569 [ 416 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.07.13 02:15:00.266236 [ 416 ] {} 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.13 02:15:00.269381 [ 416 ] {} 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.13 02:15:17.070983 [ 420 ] {bf5140bb-f7e0-41f9-b675-40776f9f0101} 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.13 02:15:27.978013 [ 420 ] {227f3446-08b1-49da-8878-9a063cc02652} 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.13 02:15:42.723983 [ 1013 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.07.13 02:15:45.668387 [ 1351 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.13 02:15:45.669385 [ 1351 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.07.13 02:15:46.926099 [ 1358 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 02:15:48.783745 [ 1351 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.13 02:15:48.833375 [ 1351 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 02:15:48.833875 [ 1351 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 02:15:48.890540 [ 1950 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 02:15:49.498515 [ 1351 ] {} 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.13 02:15:49.503253 [ 1351 ] {} 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.13 02:16:40.838876 [ 1355 ] {d4ac824b-3da6-4116-8be2-83f900f0c900} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 99.97095680236816, avg_chars_size = 110.36514816284179, limit = 8192): (while reading column Referer): (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 24 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60978) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 11. ./src/Common/PODArray.h:221: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c679d8a 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f912ff18ac3 2025.07.13 02:16:44.849208 [ 1355 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 99.97095680236816, avg_chars_size = 110.36514816284179, limit = 8192): (while reading column Referer): (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 24 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 11. ./src/Common/PODArray.h:221: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c679d8a 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f912ff18ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f912ff18ac3 12. ? @ 0x00007f912ffaa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f912ff18ac3 12. ? @ 0x00007f912ffaa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f912ff18ac3 11. ? @ 0x00007f912ffaa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f912ff18ac3 12. ? @ 0x00007f912ffaa850 2025.07.13 02:17:01.518021 [ 1355 ] {4e5ce955-3053-4331-9a47-fce08cf2fcf9} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54314) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 10. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 11. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:17:05.491157 [ 1355 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 10. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 11. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f912ff18ac3 11. ? @ 0x00007f912ffaa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f912ff18ac3 12. ? @ 0x00007f912ffaa850 2025.07.13 02:17:39.941651 [ 1951 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.07.13 02:17:41.870885 [ 2820 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.13 02:17:41.872058 [ 2820 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.07.13 02:17:43.047768 [ 2827 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 02:17:46.241166 [ 2820 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.13 02:17:46.255630 [ 2820 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 02:17:46.256402 [ 2820 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 02:17:46.315837 [ 3423 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 02:17:47.501569 [ 2820 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.07.13 02:17:47.503024 [ 2820 ] {} 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.13 02:17:47.509015 [ 2820 ] {} 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.13 02:18:14.091271 [ 3863 ] {82c14e9a-98bf-431c-b27c-44d94721e977} executeQuery: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02670_constant_skip_index.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_j2cx0a3g.t_constant_index UUID '65b57f40-f037-4e7e-8715-8ae142c1fccc' (`id` UInt64, INDEX t_constant_index 'foo' TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 21843, min_bytes_for_wide_part = 227521344, 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 = 297013384, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 22332754, merge_max_block_size = 9723, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 5111051180, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7934841999, index_granularity_bytes = 1506763, 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 = false, marks_compress_block_size = 86029, primary_key_compress_block_size = 56536, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:97: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000030e7f245 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 21. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 22. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:18:14.288369 [ 3863 ] {82c14e9a-98bf-431c-b27c-44d94721e977} executeQuery: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51100) (comment: 02670_constant_skip_index.sql) (query 2, line 4) (in query: CREATE TABLE t_constant_index (`id` UInt64, INDEX t_constant_index 'foo' TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 21843, min_bytes_for_wide_part = 227521344, 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 = 297013384, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 22332754, merge_max_block_size = 9723, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 5111051180, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7934841999, index_granularity_bytes = 1506763, 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 = false, marks_compress_block_size = 86029, primary_key_compress_block_size = 56536, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:97: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000030e7f245 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 21. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 22. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:18:14.290767 [ 3863 ] {} TCPHandler: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:97: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000030e7f245 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 21. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 22. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:18:14.578506 [ 3863 ] {172d4de6-a01e-4897-a400-9b184dd6df7f} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02670_constant_skip_index.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_j2cx0a3g.t_constant_index UUID '17503f3a-365b-4ea3-9b04-a1d8487d67e1' (`id` UInt64, INDEX t_constant_index id + rand() TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 21843, min_bytes_for_wide_part = 227521344, 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 = 297013384, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 22332754, merge_max_block_size = 9723, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 5111051180, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7934841999, index_granularity_bytes = 1506763, 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 = false, marks_compress_block_size = 86029, primary_key_compress_block_size = 56536, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x000000002cb2b54e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:87: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000030e7f09c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 21. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 22. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 23. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:14.603347 [ 3863 ] {172d4de6-a01e-4897-a400-9b184dd6df7f} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51100) (comment: 02670_constant_skip_index.sql) (query 3, line 11) (in query: CREATE TABLE t_constant_index (`id` UInt64, INDEX t_constant_index id + rand() TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 21843, min_bytes_for_wide_part = 227521344, 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 = 297013384, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 22332754, merge_max_block_size = 9723, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 5111051180, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7934841999, index_granularity_bytes = 1506763, 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 = false, marks_compress_block_size = 86029, primary_key_compress_block_size = 56536, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x000000002cb2b54e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:87: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000030e7f09c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 21. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 22. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 23. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:14.607852 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x000000002cb2b54e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:87: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000030e7f09c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 21. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 22. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 23. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:14.710919 [ 3815 ] {34c1f6ce-a8c2-4fee-9681-abbf7c5c3d40} executeQuery: Code: 36. DB::Exception: Unknown auxiliary ZooKeeper name 'zookeeper2'. If it's required it can be added to the section in config.xml. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51098) (comment: 02442_auxiliary_zookeeper_endpoint_id.sql) (query 6, line 12) (in query: CREATE TABLE t2 (`x` Int32) ENGINE = ReplicatedMergeTree('zookeeper2:/test/02442/{database}/t', 'r1') ORDER BY x SETTINGS index_granularity = 44578, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 363107482, compact_parts_max_bytes_to_buffer = 149208489, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 12817782, merge_max_block_size = 6196, 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 = 58, min_merge_bytes_to_use_direct_io = 9427186321, index_granularity_bytes = 11097392, 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 = 28333, primary_key_compress_block_size = 67676, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/Context.cpp:4252: DB::Context::getAuxiliaryZooKeeper(String const&) const @ 0x000000002d4a6d3b 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:304: DB::StorageReplicatedMergeTree::setZooKeeper() @ 0x00000000305923d5 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:462: 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&) @ 0x0000000030594ef9 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:18:14.752483 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Unknown auxiliary ZooKeeper name 'zookeeper2'. If it's required it can be added to the section in config.xml. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/Context.cpp:4252: DB::Context::getAuxiliaryZooKeeper(String const&) const @ 0x000000002d4a6d3b 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:304: DB::StorageReplicatedMergeTree::setZooKeeper() @ 0x00000000305923d5 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:462: 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&) @ 0x0000000030594ef9 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:18:15.558055 [ 3859 ] {ac79e9f8-05ed-4251-8f34-7c87761496b2} executeQuery: Code: 117. DB::Exception: Incorrect name for a database. It shouldn't be empty: In scope SELECT getMaxTableNameLengthForDatabase(''). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51126) (comment: 03253_getMaxTableNameLength.sql) (query 3, line 3) (in query: SELECT getMaxTableNameLengthForDatabase('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionGetMaxTableNameLengthForDatabase::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afb827d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:15.569722 [ 3859 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect name for a database. It shouldn't be empty: In scope SELECT getMaxTableNameLengthForDatabase(''). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionGetMaxTableNameLengthForDatabase::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afb827d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:17.695765 [ 3816 ] {14e8ad45-e7c6-44ab-8e33-1dcac65ddfa9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=769, jobs=759). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51156) (comment: 01559_aggregate_null_for_empty_fix.sql) (query 4, line 35) (in query: SELECT MaX(aggr) FROM ( SELECT mAX(-1) AS aggr FROM system.one WHERE NOT 1 UNION ALL SELECT max(-1) AS aggr FROM system.one WHERE not 1 );), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:17.727981 [ 3816 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=769, jobs=759). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.380198 [ 3815 ] {0201671d-3ca2-4799-bae4-267034685eed} executeQuery: Code: 701. DB::Exception: There is no port named unknown: In scope SELECT getServerPort('unknown'). (CLUSTER_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51196) (comment: 02012_get_server_port.sql) (query 2, line 3) (in query: select getServerPort('unknown');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/Context.cpp:4431: DB::Context::getServerPort(String const&) const @ 0x000000002d4aa86b 6. DB::(anonymous namespace)::GetServerPortOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000001afbe740 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.424530 [ 3815 ] {} TCPHandler: Code: 701. DB::Exception: There is no port named unknown: In scope SELECT getServerPort('unknown'). (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/Context.cpp:4431: DB::Context::getServerPort(String const&) const @ 0x000000002d4aa86b 6. DB::(anonymous namespace)::GetServerPortOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000001afbe740 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.801892 [ 3885 ] {bcfa9ba3-f617-477c-a132-4c1174752659} executeQuery: Code: 57. DB::Exception: Table test_3pnqllui.aine already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51228) (comment: 01073_attach_if_not_exists.sql) (query 2, line 3) (in query: ATTACH TABLE aine;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.816881 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3pnqllui.aine already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.854620 [ 2825 ] {9fda640f-38ec-4dbe-bdbc-6a34a179ca50} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60854) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.860804 [ 4142 ] {41125144-f798-4214-baeb-5f4bdd33df4e} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51252) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.868784 [ 2825 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.895223 [ 4142 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.897488 [ 4477 ] {b9b1b1bc-9fe9-4a53-934f-22e8fe1aa59e} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60882) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.905833 [ 4477 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.964498 [ 4694 ] {768aa38c-8874-4f88-974c-8e60586d8bfa} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60902) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.965896 [ 4938 ] {aeab7cb5-997a-41a1-9244-038e8aa0c4fc} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60904) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.966029 [ 5058 ] {fea55c3f-dfef-4361-a4d5-8a608bd86655} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60918) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.974102 [ 4694 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.980546 [ 4938 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:18.982542 [ 5058 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:19.168522 [ 4477 ] {a6f02a78-78ad-4031-8367-bc1e36635631} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60960) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:19.180211 [ 4477 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:19.468120 [ 3863 ] {e5e55451-7d72-4897-918c-3753850fa5cb} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60996) (comment: 00941_system_columns_race_condition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:19.551694 [ 3863 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d66a7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.069947 [ 4477 ] {6fbd5ed0-a5f9-459d-8ede-fdfbf20a2c0c} executeQuery: Code: 182. DB::Exception: Table expression test_13.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 0. (ILLEGAL_PREWHERE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60998) (comment: 02575_merge_prewhere_different_default_kind.sql) (query 8, line 29) (in query: SELECT * FROM m PREWHERE f = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d168e2f 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d1683d6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d1683d6 8. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000002d16450e 9. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd77189 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.073949 [ 4477 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_13.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 0. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d168e2f 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d1683d6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d1683d6 8. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000002d16450e 9. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd77189 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.213539 [ 3774 ] {c79763c8-eeb8-427f-a78f-4a81f8c0b670} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51132) (comment: 03036_dynamic_read_shared_subcolumns_small.gen.sql) (query 30, line 35) (in query: select d, d.UInt64, d.String, d.`Array(Variant(String, UInt64))` from test order by id, d;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.302471 [ 3774 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.692071 [ 2825 ] {1bf295b6-06a9-4955-909d-572003c8012d} executeQuery: Code: 69. DB::Exception: Cannot convert value '18446744073709551615' from UInt64: it cannot be represented as Float64. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32794) (comment: 00975_values_list.sql) (query 9, line 15) (in query: SELECT * FROM VALUES('x Float64', toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:646: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e26428b 6. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284dc786 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.697667 [ 2825 ] {} TCPHandler: Code: 69. DB::Exception: Cannot convert value '18446744073709551615' from UInt64: it cannot be represented as Float64. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:646: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e26428b 6. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284dc786 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.863132 [ 2825 ] {73529434-4af5-4db6-81f2-4d55b6db2403} executeQuery: Code: 53. DB::Exception: Cannot convert NULL to Float64. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32794) (comment: 00975_values_list.sql) (query 10, line 16) (in query: SELECT * FROM VALUES('x Float64', NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:641: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e264164 6. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284dc786 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:21.874177 [ 2825 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert NULL to Float64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:641: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e264164 6. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284dc786 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:22.956977 [ 3863 ] {07453275-243f-4ea4-afc7-ed95f4582134} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Array(Nullable(String)). In query WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33096) (comment: 03144_invalid_filter.sql) (query 3, line 6) (in query: WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca1678 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:18:22.987981 [ 3863 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Array(Nullable(String)). In query WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca1678 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:18:23.110163 [ 3863 ] {6e6186ee-c38d-4372-bf06-a80bf8a6ede6} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647'. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33096) (comment: 03144_invalid_filter.sql) (query 4, line 12) (in query: DESCRIBE TABLE (SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca1678 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x000000002e33ba69 14. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33ab97 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:18:23.116024 [ 3863 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647'. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca1678 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x000000002e33ba69 14. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33ab97 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:18:23.244733 [ 3859 ] {09221e6f-4228-4a55-aedf-7e1e6121aa89} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33024) (comment: 02552_inner_join_with_where_true.sql) (query 5, line 7) (in query: SELECT max(1), count() FROM t0 AS t0 LEFT JOIN t1 ON true WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x000000002dde53bd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2060: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda38be 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:23.266454 [ 3859 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x000000002dde53bd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2060: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda38be 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:24.369276 [ 4694 ] {9f4fd3ad-b790-43da-89ff-6cde1f4d4637} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01666_lcm_ubsan.sql) (query 1, line 1) (in query: -- { echo } SELECT lcm(9223372036854775807, -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x000000001cc1261e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001cc955f2 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fa45 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.394874 [ 4694 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x000000001cc1261e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001cc955f2 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fa45 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.474655 [ 4694 ] {9d9baebc-c482-4daa-a63d-aea0ddfb8f44} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01666_lcm_ubsan.sql) (query 2, line 3) (in query: SELECT lcm(9223372036854775808, -9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x000000001cc1261e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001cc955f2 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fa45 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.483324 [ 4694 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x000000001cc1261e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001cc955f2 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fa45 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.602627 [ 4694 ] {3b8fdd0e-04ca-41d9-bcb6-c5b041f7504a} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01666_lcm_ubsan.sql) (query 3, line 4) (in query: SELECT lcm(-9223372036854775808, 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001cc4297e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001ccda96a 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fc85 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.622611 [ 4694 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001cc4297e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001ccda96a 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fc85 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.797914 [ 4694 ] {cec9f8de-205a-41ab-8e53-8506964905c8} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01666_lcm_ubsan.sql) (query 4, line 5) (in query: SELECT lcm(-9223372036854775807, 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001cc4297e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001ccda96a 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fc85 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:24.808447 [ 4694 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x000000001cc4297e 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001ccda96a 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fc85 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:25.064988 [ 4694 ] {be2b3f32-41df-4255-ba48-b9ac83406745} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -1). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01666_lcm_ubsan.sql) (query 5, line 6) (in query: SELECT lcm(9223372036854775808, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::LCMImpl::NameLCM>::apply(unsigned long, DB::(anonymous namespace)) @ 0x000000001cc104f7 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001cc93a2c 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fa45 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:25.074862 [ 4694 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001af8e12f 5. long DB::GCDLCMImpl, DB::(anonymous namespace)::LCMImpl::NameLCM>::apply(unsigned long, DB::(anonymous namespace)) @ 0x000000001cc104f7 6. _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_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001cc93a2c 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001cc5fa45 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5e2d3 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cc5c748 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:18:25.176412 [ 4694 ] {76719405-d415-4bde-b4e1-a2f20d71aaab} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01666_lcm_ubsan.sql) (query 6, line 7) (in query: SELECT lcm(-170141183460469231731687303715884105728, -170141183460469231731687303715884105728);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001cd0d1f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbf3171 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:25.189800 [ 4694 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001cd0d1f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbf3171 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:25.476806 [ 5380 ] {4f657edc-b7f3-4004-80ff-87b50fd0b343} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.499107 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.646728 [ 5380 ] {27eb8acf-f42e-49bc-bd72-792be284bf78} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.658113 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.806236 [ 5380 ] {c38990cb-7322-40d4-8a43-feade2c1e3d4} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.840240 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.962000 [ 5380 ] {8a65075b-8c42-48a5-b4bd-20ebc7715a7d} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:25.968372 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.074045 [ 5380 ] {e2ebb98a-a6d1-45ec-8895-83b6b61171c6} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.077218 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.134343 [ 5380 ] {dce93ef2-9ca6-417a-a9a9-ee7e480f0c3b} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.165147 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.294980 [ 5380 ] {164affec-4274-4ee9-aa33-e724cabb0fe2} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.311457 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.387412 [ 5380 ] {a3d702e0-21ee-42bb-8187-69ff65ad4755} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33174) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:26.391567 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff543cc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:27.374080 [ 5080 ] {2e3069cb-43aa-4410-a943-d96acb9a13a6} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_5.data UUID '2e22099e-60fb-4f87-bda0-58f575ac4a03' (`key` Int32, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:27.413170 [ 5080 ] {2e3069cb-43aa-4410-a943-d96acb9a13a6} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 3, line 5) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:27.420121 [ 5080 ] {} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:27.657052 [ 5080 ] {d8d1931b-babf-4c83-8ada-3fa95a45f16d} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_5.data UUID 'f8723638-c938-44a1-91dd-63571e08ea7b' (`key` Int32, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:27.692344 [ 5080 ] {d8d1931b-babf-4c83-8ada-3fa95a45f16d} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 4, line 6) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:27.696951 [ 5080 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:28.202855 [ 5080 ] {64286324-24c9-4cb5-afb8-e419192e1c7c} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: /* ddl_entry=query-0000000007 */ CREATE TABLE test_5.data UUID 'e72d009a-f2e5-4c31-a8f7-f6ad51acff6f' (`key` Int32, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:28.219084 [ 5080 ] {64286324-24c9-4cb5-afb8-e419192e1c7c} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 5, line 8) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:28.228710 [ 5080 ] {} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:28.587897 [ 5080 ] {2dc7ad13-746c-4ca9-a7ca-21bdaee5ebd8} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_5.data UUID '0d7d9b73-fd83-4ea3-8d55-5cf76eb587b5' (`key` Int32, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:28.629863 [ 5080 ] {2dc7ad13-746c-4ca9-a7ca-21bdaee5ebd8} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 6, line 9) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:28.634994 [ 5080 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.227410 [ 5080 ] {3d665dae-7df6-43bd-b9ee-4f1d663361df} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_5.data UUID '2926abe2-cf32-455a-9196-226231ff701b' (`key` Int32, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.267040 [ 5080 ] {3d665dae-7df6-43bd-b9ee-4f1d663361df} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 7, line 11) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.269811 [ 5080 ] {} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.536948 [ 5080 ] {aaecaa2d-5cf3-4722-a16c-925a336b2866} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: /* ddl_entry=query-0000000010 */ CREATE TABLE test_5.data UUID 'b3cced73-671f-4d8c-ace5-808ab4231758' (`key` Int32, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.564200 [ 5080 ] {aaecaa2d-5cf3-4722-a16c-925a336b2866} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 8, line 12) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 18659, 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 = 189818377, compact_parts_max_bytes_to_buffer = 416147779, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 14921174, merge_max_block_size = 9113, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9297912394, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9163666527, index_granularity_bytes = 3582509, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, 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 = 92861, primary_key_compress_block_size = 64124, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.571498 [ 5080 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9297: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000030d620d4 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c63e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:29.871367 [ 6024 ] {f33996c2-4f81-4dcb-9f81-80ff3eadcaff} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49258) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 1, line 1) (in query: SELECT count(*) FROM distributed_00754;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:29.920589 [ 6024 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.050395 [ 3815 ] {35d06c5f-b444-425f-b37d-7d36a5587407} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49274). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:30.062674 [ 3815 ] {35d06c5f-b444-425f-b37d-7d36a5587407} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49274). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49274) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.076733 [ 3815 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49274). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.500846 [ 5080 ] {4a5eaa79-8466-47ed-97a2-7754bc1020f9} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33730) (comment: 03020_order_by_SimpleAggregateFunction.sql) (query 12, line 19) (in query: detach table data;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c782add 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.523872 [ 5080 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c782add 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.593972 [ 3815 ] {566b23b6-2180-4da4-afe4-36d77de45f1d} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49348) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 1, line 1) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:30.606002 [ 3815 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.648116 [ 5382 ] {c4c99a54-cb64-4131-b537-113c423d2c4f} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33150) (comment: 02372_analyzer_join.gen.sql) (query 27, line 63) (in query: SELECT id FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.659517 [ 5382 ] {} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.748295 [ 4694 ] {a57d1eea-238a-4686-b032-0fa47ecaa6b1} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49410). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:30.753223 [ 4694 ] {a57d1eea-238a-4686-b032-0fa47ecaa6b1} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49410). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49410) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) AND (`__table1`.`b` = 0)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.830902 [ 4694 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49410). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.863399 [ 5382 ] {d03e0b8f-5217-4738-a82b-8ac79fda2342} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33150) (comment: 02372_analyzer_join.gen.sql) (query 28, line 65) (in query: SELECT value FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.865567 [ 5382 ] {} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 INNER JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:30.937240 [ 3815 ] {c867725f-9e5a-4d8e-839e-54cb395747a4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49432) (comment: 01825_type_json_3.gen.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:31.037794 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:31.462264 [ 6070 ] {494c4e73-9179-4244-911d-2da605bf8560} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49482) (comment: 03327_permissions_on_refresh_mv.sh) (query 2, line 3) (in query: system refresh view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 9. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x000000002e302947 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:741: DB::InterpreterSystemQuery::execute() @ 0x000000002e2fa81f 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:31.468549 [ 6070 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 9. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x000000002e302947 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:741: DB::InterpreterSystemQuery::execute() @ 0x000000002e2fa81f 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:31.606726 [ 6070 ] {14e11274-b5a9-40ee-9076-b36340519dc3} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49482) (comment: 03327_permissions_on_refresh_mv.sh) (query 3, line 4) (in query: system start view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x000000002e2f3ccc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x000000002e2fa705 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:31.612229 [ 6070 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x000000002e2f3ccc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x000000002e2fa705 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.041704 [ 6070 ] {ea5ac6ef-feab-4397-8abc-9c8f0b8d5d67} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49482) (comment: 03327_permissions_on_refresh_mv.sh) (query 5, line 6) (in query: system wait view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 9. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x000000002e302947 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:745: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6c70 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.059225 [ 6070 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 9. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x000000002e302947 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:745: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6c70 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.162780 [ 3901 ] {b4f8b9db-32ec-48e0-995b-52038cff7f66} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49570) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:32.165853 [ 3901 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.237492 [ 6070 ] {53cbac3d-468e-4ab9-8c2f-5cd75ef182cc} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49482) (comment: 03327_permissions_on_refresh_mv.sh) (query 6, line 7) (in query: system stop view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x000000002e2f3ccc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x000000002e2fa705 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.240909 [ 6070 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x000000002e2f3ccc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x000000002e2fa705 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.377206 [ 6070 ] {00f2517e-63bc-4ff2-ad74-028fe322c3e4} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49482) (comment: 03327_permissions_on_refresh_mv.sh) (query 7, line 8) (in query: system cancel view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 9. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x000000002e302947 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:749: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f9522 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.411787 [ 6070 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_7_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_7.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 9. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x000000002e302947 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:749: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f9522 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.545651 [ 3792 ] {771b863e-8d5f-4b97-9293-0168a3f9f142} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49496) (comment: 01560_crash_in_agg_empty_arglist.sql) (query 3, line 5) (in query: SELECT any() as t, substring(query, 1, 70) AS query, avg(memory_usage) usage, count() count FROM system.query_log WHERE current_database = currentDatabase() AND event_date >= toDate(1604295323) AND event_time >= toDateTime(1604295323) AND type in (1,2,3,4) and initial_user in ('') and('all' = 'all' or(positionCaseInsensitive(query, 'all') = 1)) GROUP BY query ORDER BY usage desc LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./src/AggregateFunctions/FactoryHelpers.h:26: DB::IAggregateFunction* DB::createAggregateFunctionSingleValue(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000026270f23 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAny.cpp:184: DB::(anonymous namespace)::createAggregateFunctionAny(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002626f775 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:32.609948 [ 3792 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./src/AggregateFunctions/FactoryHelpers.h:26: DB::IAggregateFunction* DB::createAggregateFunctionSingleValue(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000026270f23 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAny.cpp:184: DB::(anonymous namespace)::createAggregateFunctionAny(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002626f775 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:34.516309 [ 5971 ] {d5250ef4-7576-44e3-9cb7-15dd18d768f0} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02869_insert_filenames_collisions.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_kz8rfqz0.t_collisions UUID '2aa93e11-9596-464d-9146-116daf712e81' (`very_very_long_column_name_that_will_be_replaced_with_hash` Int32, `e798545eefc8b7a1c2c81ff00c064ad8` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS replace_long_file_name_to_hash = 1, max_file_name_length = 42, index_granularity = 48268, min_bytes_for_wide_part = 755852274, ratio_of_defaults_for_sparse_serialization = 1., min_bytes_for_full_part_storage = 124075292, compact_parts_max_bytes_to_buffer = 408654125, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 10204582, merge_max_block_size = 5796, old_parts_lifetime = 67., 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 = 2333721008, index_granularity_bytes = 26452684, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 10799, primary_key_compress_block_size = 61495, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:529: 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) @ 0x0000000030c7aa8c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:34.622166 [ 5971 ] {d5250ef4-7576-44e3-9cb7-15dd18d768f0} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49796) (comment: 02869_insert_filenames_collisions.sql) (query 3, line 5) (in query: CREATE TABLE t_collisions (`very_very_long_column_name_that_will_be_replaced_with_hash` Int32, `e798545eefc8b7a1c2c81ff00c064ad8` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS replace_long_file_name_to_hash = 1, max_file_name_length = 42, index_granularity = 48268, min_bytes_for_wide_part = 755852274, ratio_of_defaults_for_sparse_serialization = 1., min_bytes_for_full_part_storage = 124075292, compact_parts_max_bytes_to_buffer = 408654125, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 10204582, merge_max_block_size = 5796, old_parts_lifetime = 67., 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 = 2333721008, index_granularity_bytes = 26452684, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 10799, primary_key_compress_block_size = 61495, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:529: 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) @ 0x0000000030c7aa8c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:34.626010 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:529: 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) @ 0x0000000030c7aa8c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:35.012502 [ 5478 ] {566fdcb9-cb30-46d7-a458-69e9cd49fbd7} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 7.82 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing MergingAggregatedTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33450) (comment: 00223_shard_distributed_aggregation_memory_efficient.sql) (query 13, line 18) (in query: SELECT sum(c = 1) IN (0, 5), sum(c = 2) IN (5, 10) FROM (SELECT number, count() AS c FROM remote('127.0.0.{2,3}', currentDatabase(), numbers_10_00223) WHERE number < (randConstant() % 2 ? 5 : 10) GROUP BY number);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:3159: DB::Aggregator::mergeBlocks(std::map>, std::less, std::allocator>>>>, DB::AggregatedDataVariants&, unsigned long, std::atomic&) @ 0x000000002d6d792d 9. ./build_docker/./src/Processors/Transforms/MergingAggregatedTransform.cpp:264: DB::MergingAggregatedTransform::generate() @ 0x000000003216077d 10. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:96: DB::IAccumulatingTransform::work() @ 0x00000000317ff48d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:35.065775 [ 5478 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 7.82 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing MergingAggregatedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:3159: DB::Aggregator::mergeBlocks(std::map>, std::less, std::allocator>>>>, DB::AggregatedDataVariants&, unsigned long, std::atomic&) @ 0x000000002d6d792d 9. ./build_docker/./src/Processors/Transforms/MergingAggregatedTransform.cpp:264: DB::MergingAggregatedTransform::generate() @ 0x000000003216077d 10. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:96: DB::IAccumulatingTransform::work() @ 0x00000000317ff48d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:35.216124 [ 5382 ] {6242d63b-8440-41a7-9235-ec2e686c3326} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:213: DB::ConcurrentHashJoin::~ConcurrentHashJoin() @ 0x000000002db92b3c 8. std::__shared_weak_count::__release_shared[abi:ne190107]() @ 0x0000000017cbf79e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:668: DB::JoiningTransform::~JoiningTransform() @ 0x0000000031dd05bc 10. std::__shared_weak_count::__release_shared[abi:ne190107]() @ 0x0000000017cbf79e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:668: std::vector, std::allocator>>::__base_destruct_at_end[abi:ne190107](std::shared_ptr*) @ 0x00000000285d60e5 12. ./contrib/llvm-project/libcxx/include/vector:979: void std::__shared_ptr_emplace, std::allocator>>, std::allocator, std::allocator>>>>::__on_zero_shared_impl[abi:ne190107], std::allocator>>>, 0>() @ 0x000000002c385d57 13. std::__shared_weak_count::__release_shared[abi:ne190107]() @ 0x0000000017cbf79e 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:668: DB::QueryPipeline::~QueryPipeline() @ 0x000000002c38bd39 15. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:700: DB::QueryPipeline::reset() @ 0x000000002c3954b2 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000316ad645 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:35.732113 [ 5971 ] {e051e8c4-6c56-43b1-9d52-d1cf851c6dce} executeQuery: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02869_insert_filenames_collisions.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_kz8rfqz0.t_collisions (ADD COLUMN `very_very_long_column_name_that_will_be_replaced_with_hash` Int32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:35.761976 [ 5971 ] {e051e8c4-6c56-43b1-9d52-d1cf851c6dce} executeQuery: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49796) (comment: 02869_insert_filenames_collisions.sql) (query 6, line 25) (in query: ALTER TABLE t_collisions ADD COLUMN very_very_long_column_name_that_will_be_replaced_with_hash Int32;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:35.764420 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.018022 [ 5058 ] {84267c48-96ab-4294-98ce-89676cf0a3a0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50000) (comment: 03214_bitslice_argument_evaluation.sql) (query 1, line 1) (in query: -- { echo } -- No arguments passed SELECT bitSlice();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.022902 [ 5058 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.057857 [ 3901 ] {f2e31968-b2bc-44b6-8f7a-a7824ff2339a} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (s) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49964) (comment: 01716_drop_rename_sign_column.sql) (query 4, line 11) (in query: ALTER TABLE signed_table DROP COLUMN s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.073157 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (s) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.082406 [ 5971 ] {00ae446c-d760-4911-974e-fe600d14161a} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02869_insert_filenames_collisions.sql) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_kz8rfqz0.t_collisions (RENAME COLUMN col1 TO very_very_long_column_name_that_will_be_replaced_with_hash)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.206397 [ 5971 ] {00ae446c-d760-4911-974e-fe600d14161a} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49796) (comment: 02869_insert_filenames_collisions.sql) (query 7, line 26) (in query: ALTER TABLE t_collisions RENAME COLUMN col1 TO very_very_long_column_name_that_will_be_replaced_with_hash;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.206932 [ 5058 ] {11d38fff-f81b-4913-87c3-485b677e099d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: UInt8: In scope SELECT bitSlice(1, 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50000) (comment: 03214_bitslice_argument_evaluation.sql) (query 2, line 4) (in query: -- Invalid 1st argument passed SELECT bitSlice(1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:36.218015 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.225785 [ 5058 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: UInt8: In scope SELECT bitSlice(1, 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:36.315340 [ 5058 ] {9c8f61eb-ff26-401b-b2b9-f5d4e82f90dd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'offset' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 'World'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50000) (comment: 03214_bitslice_argument_evaluation.sql) (query 3, line 6) (in query: -- Valid 1st argument, invalid 2nd argument passed SELECT bitSlice('Hello', 'World');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:36.321356 [ 5058 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'offset' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 'World'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:36.408987 [ 3901 ] {73448e8f-54f7-41a0-bf46-a9b8ac9937d3} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (s) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49964) (comment: 01716_drop_rename_sign_column.sql) (query 5, line 12) (in query: ALTER TABLE signed_table RENAME COLUMN s TO s1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.420181 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (s) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.497177 [ 5058 ] {32b58bfa-853a-45af-8fa3-725878d14628} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'length' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 1, 'World'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50000) (comment: 03214_bitslice_argument_evaluation.sql) (query 4, line 8) (in query: -- Valid 1st argument & 2nd argument, invalid 3rd argument passed SELECT bitSlice('Hello', 1, 'World');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.502159 [ 5058 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'length' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 1, 'World'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.589289 [ 5058 ] {9fd4068b-73d9-4093-bf67-339c98c79fc7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 4 arguments: In scope SELECT bitSlice('Hello', 1, 1, 'World'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50000) (comment: 03214_bitslice_argument_evaluation.sql) (query 5, line 10) (in query: -- More arguments then expected SELECT bitSlice('Hello', 1, 1, 'World');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:36.600975 [ 5058 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 4 arguments: In scope SELECT bitSlice('Hello', 1, 1, 'World'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019bf4b0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:37.757321 [ 3774 ] {1bf695d9-7ca6-4af7-8af8-957208275866} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): while reading column m1 at /var/lib/clickhouse/store/3e4/3e45efcf-ad13-4346-b6ce-7651d5fcbeeb/: While executing Log. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49958) (comment: 01550_type_map_formats.sql) (query 12, line 15) (in query: SELECT * FROM map_formats ORDER BY m['k1'] FORMAT CSV;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000032da74ac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c602bf0 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c5eac8e 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6939b2 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c54a24b 20. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x000000003085a7c1 21. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x0000000030859420 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:37.789008 [ 3774 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): while reading column m1 at /var/lib/clickhouse/store/3e4/3e45efcf-ad13-4346-b6ce-7651d5fcbeeb/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000032da74ac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c602bf0 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c5eac8e 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6939b2 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c54a24b 20. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x000000003085a7c1 21. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x0000000030859420 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.107369 [ 5971 ] {2078f636-2528-4219-ac1d-8b11477b9b36} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02869_insert_filenames_collisions.sql) (in query: /* ddl_entry=query-0000000008 */ ALTER TABLE test_kz8rfqz0.t_collisions (MODIFY SETTING replace_long_file_name_to_hash = 1, max_file_name_length = 42)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.130919 [ 5971 ] {2078f636-2528-4219-ac1d-8b11477b9b36} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49796) (comment: 02869_insert_filenames_collisions.sql) (query 11, line 41) (in query: ALTER TABLE t_collisions MODIFY SETTING replace_long_file_name_to_hash = 1, max_file_name_length = 42;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.134622 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.262503 [ 3901 ] {3a3e5087-4e1e-4a6c-bf29-d30a1615e762} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50212) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b <= 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:38.277444 [ 3901 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.336282 [ 3815 ] {3bd9c7fa-06d5-4323-af4a-dc72908b88a6} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:49494). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:38.399895 [ 3815 ] {3bd9c7fa-06d5-4323-af4a-dc72908b88a6} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:49494). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49494) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) AND (`__table1`.`b` <= 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.404577 [ 3815 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:49494). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.835619 [ 4477 ] {85c7ef4e-6c3a-49ec-9ec8-2fb4d8deb625} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50252) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 WHERE c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:38.861135 [ 4477 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.909184 [ 6126 ] {2b4eee32-69ef-49e4-9984-3e8aed187c24} executeQuery: Code: 48. DB::Exception: TRUNCATE DATABASE is not implemented for replicated databases. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49744) (comment: 00623_truncate_all_tables.sql) (query 21, line 27) (in query: TRUNCATE ALL TABLES FROM IF EXISTS test_5), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:402: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7e24 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:38.924464 [ 6126 ] {} TCPHandler: Code: 48. DB::Exception: TRUNCATE DATABASE is not implemented for replicated databases. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:402: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7e24 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.018801 [ 4938 ] {2432169b-0093-4f98-80c9-a342d80fc0ce} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38554). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:39.035234 [ 4938 ] {2432169b-0093-4f98-80c9-a342d80fc0ce} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38554). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38554) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1` PREWHERE `__table1`.`a` = 0 WHERE `__table1`.`c` LIKE '%l%'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.040631 [ 4938 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38554). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.146677 [ 5971 ] {33c7c030-5c2c-4a3a-8ff1-e8f8b62c1d37} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name 64686c69296a8effce24efb0c542715b. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02869_insert_filenames_collisions.sql) (in query: /* ddl_entry=query-0000000010 */ CREATE TABLE test_kz8rfqz0.t_collisions UUID '086239cc-913c-4346-9c7c-c115e55beb4d' (`id` Int32, `col` Array(String), `col.s` Array(LowCardinality(String)), `col.u` Array(LowCardinality(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 48268, min_bytes_for_wide_part = 755852274, 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 = 124075292, compact_parts_max_bytes_to_buffer = 408654125, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 10204582, merge_max_block_size = 5796, old_parts_lifetime = 67., 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 = 2333721008, index_granularity_bytes = 26452684, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 10799, primary_key_compress_block_size = 61495, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:529: 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) @ 0x0000000030c7aa8c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:39.220197 [ 5971 ] {33c7c030-5c2c-4a3a-8ff1-e8f8b62c1d37} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name 64686c69296a8effce24efb0c542715b. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49796) (comment: 02869_insert_filenames_collisions.sql) (query 15, line 49) (in query: CREATE TABLE t_collisions (`id` Int, `col` Array(String), `col.s` Array(LowCardinality(String)), `col.u` Array(LowCardinality(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 48268, min_bytes_for_wide_part = 755852274, 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 = 124075292, compact_parts_max_bytes_to_buffer = 408654125, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 10204582, merge_max_block_size = 5796, old_parts_lifetime = 67., 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 = 2333721008, index_granularity_bytes = 26452684, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 10799, primary_key_compress_block_size = 61495, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:529: 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) @ 0x0000000030c7aa8c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:39.222648 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name 64686c69296a8effce24efb0c542715b. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:529: 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) @ 0x0000000030c7aa8c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:39.555090 [ 4938 ] {48e5b8b3-9337-4cb6-a3e3-ebb06d7ad836} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38568) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 OR a = 1 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:39.562034 [ 4938 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.718496 [ 6249 ] {e6f772ab-ced6-4342-9285-ee8752f8831e} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38598). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:39.722448 [ 6249 ] {e6f772ab-ced6-4342-9285-ee8752f8831e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38598). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38598) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) OR ((`__table1`.`a` = 1) AND (`__table1`.`b` = 0))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.724289 [ 6249 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38598). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.795044 [ 5382 ] {40bbefcb-5bd8-4ca7-8b29-d98f8e62052d} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33150) (comment: 02372_analyzer_join.gen.sql) (query 52, line 122) (in query: SELECT id FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:39.881951 [ 5382 ] {} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.078644 [ 5971 ] {c09ae080-8874-4987-b671-53efd3fb40d5} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name 64686c69296a8effce24efb0c542715b. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02869_insert_filenames_collisions.sql) (in query: /* ddl_entry=query-0000000012 */ ALTER TABLE test_kz8rfqz0.t_collisions (MODIFY COLUMN `col` Array(String))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.087084 [ 5382 ] {b86e5bcf-60fa-4302-a422-4daf8807d4b0} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33150) (comment: 02372_analyzer_join.gen.sql) (query 53, line 124) (in query: SELECT value FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.089305 [ 5382 ] {} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON test_table_join_1.id = test_table_join_2.id ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1 LEFT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14b79b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d148638 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.129122 [ 4938 ] {6f004a03-1a0a-4e41-9fcf-956d1d86a71a} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 1, line 303) (in query: SELECT runningDifference(CAST(NULL AS Nullable(Float32)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.161303 [ 4938 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.190947 [ 5971 ] {c09ae080-8874-4987-b671-53efd3fb40d5} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name 64686c69296a8effce24efb0c542715b. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49796) (comment: 02869_insert_filenames_collisions.sql) (query 18, line 71) (in query: ALTER TABLE t_collisions MODIFY COLUMN col Array(String);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.194137 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name 64686c69296a8effce24efb0c542715b. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7735: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000030c7fd18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7685: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000030cde8b8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3859: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd4250 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.211939 [ 4938 ] {7c17e9c8-70f7-4d21-9d8f-1df29ce044de} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 2, line 304) (in query: SELECT runningDifference(CAST(NULL AS Nullable(Float64)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.237316 [ 4938 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.350407 [ 5103 ] {6559dc2f-47ec-4d07-bb30-9d031310e904} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38620) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:40.351682 [ 4938 ] {ab59ba24-d389-4e35-a873-9638d3d0f5ae} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 3, line 305) (in query: SELECT runningDifference(CAST(NULL AS Nullable(Date)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.355428 [ 4938 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.376265 [ 5103 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.525021 [ 4938 ] {cbbc2358-aea0-4b82-ae6f-71dba0ee7cef} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 4, line 306) (in query: SELECT runningDifference(CAST(NULL AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.529406 [ 4938 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:40.564897 [ 2824 ] {627b1477-a22f-4b2a-89e7-75824e8bb0ba} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38660). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:40.571145 [ 2824 ] {627b1477-a22f-4b2a-89e7-75824e8bb0ba} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38660). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38660) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1` PREWHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR ((`__table1`.`a` = 2) AND (`__table1`.`b` = 2))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:40.578299 [ 2824 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38660). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:41.041424 [ 3774 ] {df8332c9-3c8b-42ff-a201-78e6f60deab1} executeQuery: Code: 81. DB::Exception: Database _table_function does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50232) (comment: 00098_shard_i_union_all.sql) (query 8, line 13) (in query: SELECT * FROM (SELECT id, event_date, priority, description FROM remote('127.0.0.{2,3}', currentDatabase(), report1) UNION ALL SELECT id, event_date, priority, description FROM remote('127.0.0.{2,3}', currentDatabase(), report2)) ORDER BY id, event_date ASC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa05e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4b65df 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d13fbf3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29c14 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc581e1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./build_docker/./src/Processors/QueryPlan/ParallelReplicasLocalPlan.cpp:57: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x00000000321690f2 18. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:627: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d5847 19. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95708 20. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Planner/Planner.cpp:1363: DB::Planner::buildPlanForUnionNode() @ 0x000000002dd74a0f 23. ./build_docker/./src/Planner/Planner.cpp:1321: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cab 24. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 26. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 27. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 28. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:18:41.100898 [ 3774 ] {} TCPHandler: Code: 81. DB::Exception: Database _table_function does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa05e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4b65df 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d13fbf3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29c14 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc581e1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./build_docker/./src/Processors/QueryPlan/ParallelReplicasLocalPlan.cpp:57: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x00000000321690f2 18. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:627: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d5847 19. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95708 20. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Planner/Planner.cpp:1363: DB::Planner::buildPlanForUnionNode() @ 0x000000002dd74a0f 23. ./build_docker/./src/Planner/Planner.cpp:1321: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cab 24. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 26. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 27. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 28. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:18:41.101118 [ 4694 ] {c2cbbfcc-f692-41b2-b88b-6b4313124bfb} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38676) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:41.123142 [ 4694 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314e3e98 5. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314d1db7 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3d9bc5 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3ceba7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3c1781 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 11. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 13. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:41.251782 [ 2825 ] {0e272cbc-2715-4b42-b456-e2d94069e3c8} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38680). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:41.257781 [ 2825 ] {0e272cbc-2715-4b42-b456-e2d94069e3c8} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38680). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38680) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_ue4v6q5l`.`mergetree_00754` AS `__table1` PREWHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR (`__table1`.`c` LIKE '%l%')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:41.260196 [ 2825 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38680). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:42.986111 [ 3455 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d8b624c5-d643-4a2a-aaf9-5c25097d34b6::202507_1_16_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:43.062441 [ 5103 ] {e4bf3eed-ce9a-4f89-8eed-10752f671a2e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=31, jobs=18): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 0 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38818) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:43.085441 [ 5103 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=31, jobs=18): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 0 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.200453 [ 3815 ] {ad35b1e5-a3fb-4ab2-949c-3bb5f773d151} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=30, jobs=22): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_5_5_0/data.bin (position: 1810765, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a57b9d790d8f70e63821c41b953c6039828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_5_5_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 27 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38792) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:43.215252 [ 3815 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=30, jobs=22): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_5_5_0/data.bin (position: 1810765, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a57b9d790d8f70e63821c41b953c6039828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_5_5_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 27 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.316977 [ 3901 ] {38ddc094-1559-4673-8b81-7dd75e51fad0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=6): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38760) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.348706 [ 3901 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=6): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.429847 [ 3774 ] {4a732d86-be63-41f0-9994-18c6c599b53e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38806) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.451661 [ 3774 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.758512 [ 6126 ] {ae7f6444-10a1-4c4d-bce1-b60b785b0231} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=31, jobs=26): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 1185228, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b7d7b985d9af47d62bb866a4a3b6f8a5828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 18 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38774) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:43.773993 [ 6126 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=31, jobs=26): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 1185228, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b7d7b985d9af47d62bb866a4a3b6f8a5828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 18 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:43.988715 [ 6070 ] {a8f3bfd7-f699-4a1c-a834-f7f7ac7f8852} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=31): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/data.bin (position: 658460, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e34b5c01cae7d31b0ba052a92bde8c9e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 10 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38750) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:44.007970 [ 6070 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=31): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/data.bin (position: 658460, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e34b5c01cae7d31b0ba052a92bde8c9e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 10 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.023947 [ 6249 ] {53de0354-ea30-4da7-a1ea-c1644cb32cfa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=27): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/data.bin (position: 362153, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 01741f55fe399641235a0019bffc6c70828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 5 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38820) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:44.054155 [ 6951 ] {74ae6d42-c643-49ff-ae46-12d594d49255} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38938) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.057955 [ 6249 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=27): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/data.bin (position: 362153, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 01741f55fe399641235a0019bffc6c70828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 5 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.081993 [ 6951 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.270213 [ 3774 ] {88287476-4891-47d8-9e15-1d72374f7ae5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=21): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 197538, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3e017423882cfdf441f361cf8490939e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 3 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38906) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:44.276177 [ 3774 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=21): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 197538, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3e017423882cfdf441f361cf8490939e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 3 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.321149 [ 5971 ] {4994ad0c-2807-4d5b-8deb-df062e561478} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=27): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 1448612, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 171d69ab0524ec2b5840b08c3114fbc9828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 22 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38780) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:44.340664 [ 5971 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=27): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 1448612, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 171d69ab0524ec2b5840b08c3114fbc9828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 22 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.699061 [ 6024 ] {94467b8c-1bbc-4080-aec2-836115027b60} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49982) (comment: 00458_merge_type_cast.sql) (query 58, line 85) (in query: DROP TABLE IF EXISTS merge_one_two;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.706845 [ 6022 ] {8e1a7741-98d0-4f8d-8a39-3e9921fc232d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=47, jobs=33): While reading or decompressing /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/data.bin (position: 510, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 233fee7e38bd5b1c3270bb0c63ee3274021200000009000000): (while reading column value_bug): (while reading from part /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/ in table test_w989rccp.bug_delta_gorilla (d221bb49-5962-441e-9dd9-740afc1d7559) located on disk default of type local, from mark 15 with max_rows_to_read = 81920): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:58270) (comment: 02536_delta_gorilla_corruption.sql) (query 6, line 17) (in query: SELECT count() AS `count()` FROM `test_w989rccp`.`bug_delta_gorilla` AS `__table1` WHERE 0 != `__table1`.`value_bug`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:44.720032 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.746144 [ 6022 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=47, jobs=33): While reading or decompressing /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/data.bin (position: 510, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 233fee7e38bd5b1c3270bb0c63ee3274021200000009000000): (while reading column value_bug): (while reading from part /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/ in table test_w989rccp.bug_delta_gorilla (d221bb49-5962-441e-9dd9-740afc1d7559) located on disk default of type local, from mark 15 with max_rows_to_read = 81920): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.816822 [ 5072 ] {d98ae883-4da4-4121-be59-41ef6b51663e} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=47, jobs=33): While reading or decompressing /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/data.bin (position: 510, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 233fee7e38bd5b1c3270bb0c63ee3274021200000009000000): (while reading column value_bug): (while reading from part /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/ in table test_w989rccp.bug_delta_gorilla (d221bb49-5962-441e-9dd9-740afc1d7559) located on disk default of type local, from mark 15 with max_rows_to_read = 81920): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50138) (comment: 02536_delta_gorilla_corruption.sql) (query 6, line 17) (in query: select count(*) from bug_delta_gorilla where 0 <> value_bug;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:44.860895 [ 5072 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=47, jobs=33): While reading or decompressing /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/data.bin (position: 510, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 233fee7e38bd5b1c3270bb0c63ee3274021200000009000000): (while reading column value_bug): (while reading from part /var/lib/clickhouse/store/d22/d221bb49-5962-441e-9dd9-740afc1d7559/all_10_10_0/ in table test_w989rccp.bug_delta_gorilla (d221bb49-5962-441e-9dd9-740afc1d7559) located on disk default of type local, from mark 15 with max_rows_to_read = 81920): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:44.926530 [ 5379 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38998, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:44.929845 [ 5379 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38998, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:45.090911 [ 3458 ] {d221bb49-5962-441e-9dd9-740afc1d7559::all_6_10_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c5a377 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3bbd14 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c260b8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:45.109215 [ 3452 ] {d221bb49-5962-441e-9dd9-740afc1d7559::all_1_5_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:45.109278 [ 3466 ] {d221bb49-5962-441e-9dd9-740afc1d7559::all_11_15_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:45.675212 [ 6126 ] {4d483484-80ac-4dab-a14c-be44d88d55a9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=34): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 724306, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b23b05bc3476e35a36e30e7450ca2554828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 11 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38944) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:45.687779 [ 6126 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=34): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 724306, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b23b05bc3476e35a36e30e7450ca2554828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 11 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:45.775859 [ 4694 ] {a66e45e9-0baa-41ad-89c7-d8ae03eca015} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38844) (comment: 00740_database_in_nested_view.sql) (query 18, line 23) (in query: DROP TABLE IF EXISTS test_zrt2qa8o.test_nested_view_00740), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:45.801992 [ 4694 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:46.008892 [ 4694 ] {e2a2ce36-965d-4074-ab53-938536ac6035} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34110) (comment: 00740_database_in_nested_view.sql) (in query: DROP DATABASE IF EXISTS test_zrt2qa8o SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:18:46.011774 [ 4694 ] {e2a2ce36-965d-4074-ab53-938536ac6035} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:46.245307 [ 5382 ] {b2b558fc-ddae-4d02-83ff-7e01e521935b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33150) (comment: 02372_analyzer_join.gen.sql) (query 70, line 163) (in query: SELECT test_table_join_1.id, test_table_join_1.value, test_table_join_2.id, test_table_join_2.value FROM test_table_join_1 RIGHT JOIN test_table_join_2 ON test_table_join_1.id = test_table_join_2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:54: DB::QueryPlanOptimizations::estimateReadRowsCount(DB::QueryPlan::Node&, bool) @ 0x000000003229803f 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:0: DB::QueryPlanOptimizations::estimateReadRowsCount(DB::QueryPlan::Node&, bool) @ 0x00000000322983d6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:340: DB::QueryPlanOptimizations::optimizeJoinLogical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003229b45e 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:157: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f24 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:46.261718 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:54: DB::QueryPlanOptimizations::estimateReadRowsCount(DB::QueryPlan::Node&, bool) @ 0x000000003229803f 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:0: DB::QueryPlanOptimizations::estimateReadRowsCount(DB::QueryPlan::Node&, bool) @ 0x00000000322983d6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:340: DB::QueryPlanOptimizations::optimizeJoinLogical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003229b45e 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:157: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f24 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:18:46.519245 [ 3815 ] {63101d1d-ff72-4abd-811f-a4ffec611fc8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=36): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 5563987, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 29d9ea067225f58662bc48f42f1a615b828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 84 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38872) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:46.644709 [ 3815 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=36): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 5563987, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 29d9ea067225f58662bc48f42f1a615b828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 84 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:46.994448 [ 3901 ] {f1d8100f-00f6-41e8-ad03-1079daac7d20} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=36): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/data.bin (position: 7934443, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 74cef9382a268c2cac440fa77235c9e4828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 120 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38888) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:47.009665 [ 3901 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=36): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/data.bin (position: 7934443, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 74cef9382a268c2cac440fa77235c9e4828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_6_6_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 120 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:47.093814 [ 7056 ] {38ab7cdb-e563-4103-9d0f-229d60781f7d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=23): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 2205841, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 1007fe95965112718d279d9c8863d5e5828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 33 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39000) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:47.105876 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=23): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 2205841, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 1007fe95965112718d279d9c8863d5e5828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 33 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:47.115094 [ 6249 ] {252d3202-ae19-4639-bced-f7f3eb323052} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=33): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 2798455, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 59c705275a8ca3c5c2440b45fabbff97828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 42 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38970) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:47.188908 [ 6249 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=33): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 2798455, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 59c705275a8ca3c5c2440b45fabbff97828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 42 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:47.626900 [ 3774 ] {2dc0131d-c6ff-4333-b00a-f7d7ca480590} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=16): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 2370456, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 9aff7fd5bc62bfb0b069c0f06e457aff828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 36 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39040) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:47.660064 [ 3774 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=16): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 2370456, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 9aff7fd5bc62bfb0b069c0f06e457aff828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 36 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:47.885865 [ 3901 ] {a8958701-2135-4fe1-bc49-d29c3d5d9d1f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=39): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 427999, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6517bfbaa9dab86a8f49170170731148828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 6 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39124) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:47.899590 [ 3901 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=39): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 427999, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6517bfbaa9dab86a8f49170170731148828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 6 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:49.601783 [ 5971 ] {4dc45a1a-ee0a-4b51-8dbd-929dd36da6eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=39): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_4_4_0/data.bin (position: 6090755, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 88029ba5f95a3b43dc970f681dd617a3828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_4_4_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 92 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39012) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:49.692337 [ 5971 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=39): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_4_4_0/data.bin (position: 6090755, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 88029ba5f95a3b43dc970f681dd617a3828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_4_4_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 92 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:49.972896 [ 6249 ] {50bd09c9-9635-4498-95c7-d9dc078a8810} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=32): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 32923, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: f416012681702bf83ecca2995210314c828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 0 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39140) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:49.985871 [ 6249 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=32): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 32923, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: f416012681702bf83ecca2995210314c828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 0 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.020183 [ 3815 ] {75f1dab2-0621-42fe-8c47-032bf7b1b049} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=29): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 4773835, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6706501d12148e33971f3474c48f2bde828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 72 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39106) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:50.030136 [ 3815 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=29): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 4773835, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6706501d12148e33971f3474c48f2bde828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 72 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.272230 [ 4938 ] {4ebb6a4c-5e71-4454-9168-c65f74f47d19} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Int8: In scope SELECT tupleElement(CAST(1, 'Int8'), sumState(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 70, line 373) (in query: SELECT tupleElement(CAST(1 AS Int8),sumState(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0550b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.278780 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Int8: In scope SELECT tupleElement(CAST(1, 'Int8'), sumState(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0550b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.381412 [ 6070 ] {f81782da-b743-4998-8803-f0ac8d7f4b07} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=23): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/data.bin (position: 5267603, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7c65cf95829f262ccc53b22df0c953e7828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 80 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38966) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7c2a 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:18:50.394467 [ 5103 ] {42c234b6-6f4c-461d-a4e5-3b6f6307f616} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=26): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/data.bin (position: 4971296, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0c7f1c70ba4bf8335c607e019244f65b828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 75 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39010) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7c2a 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:18:50.412120 [ 5103 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=26): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/data.bin (position: 4971296, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0c7f1c70ba4bf8335c607e019244f65b828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 75 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7c2a 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.424598 [ 6070 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=23): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/data.bin (position: 5267603, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7c65cf95829f262ccc53b22df0c953e7828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_1_1_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 80 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7c2a 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.792884 [ 5732 ] {03616abd-b6a7-48b3-8e5f-3e2dab539e4c} executeQuery: Code: 57. DB::Exception: Table test_qloe55mq.distributed_01099_b already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01099_parallel_distributed_insert_select.sql) (in query: /* ddl_entry=query-0000000012 */ CREATE TABLE test_qloe55mq.distributed_01099_b UUID '934bbcfb-5b9e-4a9d-a964-de44198cd260' (`number` UInt64) ENGINE = Distributed('test_cluster_two_shards_localhost', currentDatabase(), local_01099_b, rand())), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.846268 [ 5732 ] {03616abd-b6a7-48b3-8e5f-3e2dab539e4c} executeQuery: Code: 57. DB::Exception: Table test_qloe55mq.distributed_01099_b already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38834) (comment: 01099_parallel_distributed_insert_select.sql) (query 26, line 49) (in query: CREATE TABLE distributed_01099_b AS local_01099_b ENGINE = Distributed('test_cluster_two_shards_localhost', currentDatabase(), local_01099_b, rand());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.863088 [ 5732 ] {} TCPHandler: Code: 57. DB::Exception: Table test_qloe55mq.distributed_01099_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.864665 [ 5103 ] {8b2bb330-4386-45cf-9d47-9207b986028b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40078) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.897659 [ 5103 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.902645 [ 5058 ] {7eedd7e9-e277-4bcf-bac3-3413ca9bd209} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 92.23 MiB (attempt to allocate chunk of 1.13 MiB), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38924) (comment: 01799_long_uniq_theta_sketch.sql) (query 21, line 36) (in query: SELECT uniqExact(number) FROM numbers(1e7);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399291f 9. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000026d21620 10. ./src/Common/HashTable/HashTable.h:926: DB::AggregateFunctionUniq>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000026d15815 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6c2dd2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6c3604 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7a7d 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.932334 [ 5058 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 92.23 MiB (attempt to allocate chunk of 1.13 MiB), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399291f 9. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000026d21620 10. ./src/Common/HashTable/HashTable.h:926: DB::AggregateFunctionUniq>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000026d15815 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6c2dd2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6c3604 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7a7d 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:50.995790 [ 3774 ] {e00b845c-cbce-4981-895f-32849dec12f2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=37): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_7_7_0/data.bin (position: 1448612, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 47b629b4b9bdec49e4c7764a345e088b828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_7_7_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 22 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39176) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:51.006999 [ 3774 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=37): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_7_7_0/data.bin (position: 1448612, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 47b629b4b9bdec49e4c7764a345e088b828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_7_7_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 22 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.353734 [ 4938 ] {423dd1c0-0384-4430-bc76-e2133e24f35f} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 78, line 381) (in query: SELECT or(CAST(1 AS Int8),CAST( 0 AS Nullable(Date)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.362469 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.432375 [ 4938 ] {61d6b89c-53e9-4a05-8dab-7dbbca263382} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 79, line 382) (in query: SELECT or(CAST(1 AS Int8),CAST( 0 AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.455362 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.517979 [ 4938 ] {1555bf4a-44b5-42ee-bfe2-be697b941519} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(Enum8('0' = 0, 'z' = 1))) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST('0', 'Nullable(Enum8(\'0\' = 0, \'z\' = 1))'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 80, line 383) (in query: SELECT or(CAST(1 AS Int8),CAST( '0' AS Nullable(Enum8('0' = 0, 'z' = 1))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.614684 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(Enum8('0' = 0, 'z' = 1))) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST('0', 'Nullable(Enum8(\'0\' = 0, \'z\' = 1))'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.900639 [ 4938 ] {32b3c79b-7829-4b9f-ac80-0d99b6a5471a} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 82, line 385) (in query: SELECT or(CAST(1 AS Int8),CAST(NULL AS Nullable(Date)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.911134 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.987875 [ 4938 ] {cd64d35c-abb6-4794-bafa-16c0fbca3ed6} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 83, line 386) (in query: SELECT or(CAST(1 AS Int8),CAST(NULL AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:51.997470 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.114316 [ 4938 ] {f9fc02eb-672d-448c-919a-66f41ac65f3e} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int64') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 84, line 387) (in query: SELECT or(CAST(1 AS Int64),CAST(NULL AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.124759 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int64') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad48ec4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.236644 [ 5971 ] {459681ab-b777-403e-80e2-ddb8002f639c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40156) (comment: 01825_type_json_mutations.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.248224 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.391951 [ 5380 ] {a12ef5cf-c310-4055-868d-815bba10d06d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=37): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 5959063, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 60ccb4db889738d595e917cf3a873535828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 90 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40062) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:52.411674 [ 5380 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=37): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 5959063, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 60ccb4db889738d595e917cf3a873535828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 90 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.709615 [ 6024 ] {04a606d8-9b86-4f70-b16c-0c9101c85163} executeQuery: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39090) (comment: 01289_min_execution_speed_not_too_early.sql) (query 4, line 6) (in query: SET max_execution_time = 100, timeout_before_checking_execution_speed = 100, max_execution_speed = 1000000, max_threads = 1, max_block_size = 1000000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.732522 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.763127 [ 5072 ] {670868af-cd73-41cb-b1ee-9799afab0782} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39168) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.783318 [ 5072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.838085 [ 6951 ] {a28f6619-1c48-41d6-a10d-286a9f0dc8e7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=29): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 3555684, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6cc4bcd03e839d943af2098261f92d1b828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 54 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40052) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:52.849262 [ 6951 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=29): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/data.bin (position: 3555684, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6cc4bcd03e839d943af2098261f92d1b828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_9_9_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 54 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:52.873682 [ 3455 ] {4122180a-c8cf-4590-8f0d-0123d0db2c03::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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:53.066140 [ 5478 ] {9a3c99d2-ab3b-44f3-8582-aa3df98ce377} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.name, 'all_0_5_1_6'_String) :: 2) -> throwIf(equals(__table1.name, 'all_0_5_1_6'_String)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50150) (comment: 02446_parent_zero_copy_locks.sql) (query 14, line 26) (in query: -- wait for parts to be merged select throwIf(name = 'all_0_5_1_6') from system.parts where database=currentDatabase() and table like 'rmt%' and active format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:18:53.071702 [ 5478 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.name, 'all_0_5_1_6'_String) :: 2) -> throwIf(equals(__table1.name, 'all_0_5_1_6'_String)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:53.218562 [ 4938 ] {fada09f8-cbfd-44a2-8a3e-b9b5aaf6bf84} executeQuery: Code: 44. DB::Exception: Second argument for function toFixedString must be unsigned integer: In scope SELECT toFixedString('', CAST(9223372036854775807, 'Int64')). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 94, line 398) (in query: SELECT toFixedString('',CAST(9223372036854775807 as Int64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ae1463 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:53.244791 [ 7056 ] {9124132f-77b4-446b-9a06-b826aedc6773} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=31): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 592614, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5f382fc89a3e64c8c8f8d90157d06e70828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 9 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40114) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:18:53.254267 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=31): While reading or decompressing /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/data.bin (position: 592614, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5f382fc89a3e64c8c8f8d90157d06e70828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/5c3/5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5/all_8_8_0/ in table test_13.t_index_hypothesis (5c3389f2-40ab-4ece-bb4f-9e47a9e10ea5) located on disk default of type local, from mark 9 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:53.297876 [ 4938 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toFixedString must be unsigned integer: In scope SELECT toFixedString('', CAST(9223372036854775807, 'Int64')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ae1463 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:53.993048 [ 5476 ] {bda97ce7-ca33-412a-a571-1792ee7f614a} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 5.00, current rows: 20.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44350) (comment: 01460_mark_inclusion_search_crash.sql) (query 6, line 10) (in query: SELECT toUInt32(`__table1`.`x`) AS `toUInt32(x)`, `__table1`.`y` AS `y`, `__table1`.`z` AS `z` FROM `test_o7f8a5i8`.`pk` AS `__table1` WHERE (`__table1`.`x` >= _CAST(100000, 'DateTime')) AND (`__table1`.`x` <= _CAST(90000, 'DateTime'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.010158 [ 5476 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 5.00, current rows: 20.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.050588 [ 6249 ] {d8f2ae4a-ebe3-4001-a071-60a410beb766} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 5.00, current rows: 20.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37514) (comment: 01460_mark_inclusion_search_crash.sql) (query 6, line 10) (in query: SELECT toUInt32(`__table1`.`x`) AS `toUInt32(x)`, `__table1`.`y` AS `y`, `__table1`.`z` AS `z` FROM `test_o7f8a5i8`.`pk` AS `__table1` WHERE (`__table1`.`x` >= _CAST(100000, 'DateTime')) AND (`__table1`.`x` <= _CAST(90000, 'DateTime'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.072531 [ 6249 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 5.00, current rows: 20.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.077107 [ 5971 ] {689cc68a-aeb1-47a3-9eb5-db54d4784baf} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 5.00, current rows: 20.00. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 : While executing Remote. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40170) (comment: 01460_mark_inclusion_search_crash.sql) (query 6, line 10) (in query: SELECT toUInt32(x), y, z FROM pk WHERE (x >= toDateTime(100000)) AND (x <= toDateTime(90000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:18:54.079068 [ 6249 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37514, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:54.088145 [ 6249 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37514, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:54.088576 [ 5971 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 5.00, current rows: 20.00. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.289177 [ 5058 ] {f8c245d1-a38b-44c6-bf25-5eaf847b83ce} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49006) (comment: 01460_mark_inclusion_search_crash.sql) (in query: DROP DATABASE IF EXISTS test_o7f8a5i8 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.292284 [ 5058 ] {f8c245d1-a38b-44c6-bf25-5eaf847b83ce} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:54.545078 [ 4694 ] {da4c3dee-8c15-424d-af63-bb7d2544a5fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 1, line 1) (in query: -- error cases SELECT extractAllGroupsHorizontal();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.583011 [ 4694 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.654954 [ 4694 ] {2c2a8f36-93df-4765-80af-a511f69dcd98} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 2, line 3) (in query: SELECT extractAllGroupsHorizontal('hello');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.666218 [ 4694 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.836219 [ 4694 ] {b023135a-fe7e-467a-8244-562d29773197} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 3, line 4) (in query: SELECT extractAllGroupsHorizontal('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad6c3aa 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:54.836998 [ 5732 ] {a3416b78-7e87-4507-9ffc-780fea02081a} executeQuery: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40226) (comment: 03362_join_where_false_76670.sql) (query 8, line 12) (in query: SELECT * FROM t1 RIGHT JOIN t0 AS t2 ON NOT t0.x = t2.x WHERE false ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032147791 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.862357 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad6c3aa 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:54.863089 [ 5732 ] {} TCPHandler: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032147791 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:18:54.953588 [ 4694 ] {39380aa6-f507-49aa-a62d-fd2349c4edc9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 4, line 5) (in query: SELECT extractAllGroupsHorizontal(123, 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad6c3aa 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:54.961796 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad6c3aa 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:55.168542 [ 4694 ] {cc3e3b08-29a2-4633-9644-b81c86e99112} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsHorizontal('hello world', '((('). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 5, line 6) (in query: SELECT extractAllGroupsHorizontal('hello world', '(((');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6a551 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:18:55.175627 [ 4694 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsHorizontal('hello world', '((('). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6a551 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:18:55.276144 [ 4694 ] {b51e55a1-c863-4882-abb8-c7301de56a35} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: String: In scope SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+')). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 6, line 7) (in query: SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad6c3aa 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:55.286290 [ 4694 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: String: In scope SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad6c3aa 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:55.524566 [ 4694 ] {8fd0bc92-bcbd-4d8a-a22c-6d2bc6f8875f} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsHorizontal('hello world', '\\w+'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 7, line 8) (in query: SELECT extractAllGroupsHorizontal('hello world', '\\w+');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6bb2d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:55.607133 [ 4694 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsHorizontal('hello world', '\\w+'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6bb2d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:55.718726 [ 4694 ] {1245d819-f078-4e91-900c-11e2e320a5fc} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 0) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 8, line 9) (in query: SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6b82d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:55.731966 [ 4694 ] {} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 0) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6b82d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:55.800317 [ 4694 ] {1b065933-dc45-46e6-94ba-37a65be67781} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 1) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01246_extractAllGroupsHorizontal.sql) (query 9, line 10) (in query: SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6b82d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:55.826149 [ 4694 ] {} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 1) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6b82d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:18:56.862244 [ 6249 ] {8151a8d0-86d9-4cb3-95df-191c20aaef43} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c413796 6. auto DB::impl_::decimalResultType, DB::Decimal, DB::DataTypeDecimal>(DB::DataTypeDecimal> const&, DB::Decimal> const&) @ 0x000000001f157d67 7. 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 @ 0x000000001f381607 8. 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&&) @ 0x000000001f37f17f 9. 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 @ 0x000000001f35fd12 10. 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&&) @ 0x000000001f35f75f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35e744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f063e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:18:56.880020 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c413796 6. auto DB::impl_::decimalResultType, DB::Decimal, DB::DataTypeDecimal>(DB::DataTypeDecimal> const&, DB::Decimal> const&) @ 0x000000001f157d67 7. 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 @ 0x000000001f381607 8. 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&&) @ 0x000000001f37f17f 9. 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 @ 0x000000001f35fd12 10. 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&&) @ 0x000000001f35f75f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35e744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f063e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:18:57.181937 [ 6249 ] {f14125b9-32cf-46cd-b6d5-8c7180e3e897} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c413f56 6. auto DB::impl_::decimalResultType>, DB::Decimal>, DB::DataTypeDecimal>(DB::DataTypeDecimal>> const&, DB::Decimal>>> const&) @ 0x000000001f17b647 7. 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 @ 0x000000001f384b07 8. 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&&) @ 0x000000001f3824bf 9. 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 @ 0x000000001f35fd72 10. 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&&) @ 0x000000001f35f79f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35e744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f063e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:18:57.189519 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c413f56 6. auto DB::impl_::decimalResultType>, DB::Decimal>, DB::DataTypeDecimal>(DB::DataTypeDecimal>> const&, DB::Decimal>>> const&) @ 0x000000001f17b647 7. 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 @ 0x000000001f384b07 8. 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&&) @ 0x000000001f3824bf 9. 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 @ 0x000000001f35fd72 10. 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&&) @ 0x000000001f35f79f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35e744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f063e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:18:57.340133 [ 7213 ] {f59f5551-2f57-4efb-8dfc-64e2d637ec2b} BackupsWorker: Failed to restore from backup Disk('backups', 'test_11/mt_250_parts.zip'): Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 13.02 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b2ceca 11. ./build_docker/./src/IO/ReadBufferFromFileBase.cpp:17: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x0000000023b2c424 12. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:232: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd557 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 14. ./build_docker/./src/Backups/BackupImpl.cpp:743: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf8695b 15. ./build_docker/./src/Backups/BackupImpl.cpp:868: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf880d8 16. ./build_docker/./src/Backups/BackupImpl.cpp:798: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf87a85 17. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6098: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x0000000030d186c7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6041: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d74096 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c03579a 20. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (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&&) @ 0x000000002c034e79 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c027cee 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:1169: DB::RestorerFromBackup::runDataRestoreTasks() @ 0x000000002c0278db 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:177: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c021279 8. ./build_docker/./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&) @ 0x000000002bf4f389 9. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 10. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf47eb4 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476c8 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:57.412702 [ 5732 ] {f59f5551-2f57-4efb-8dfc-64e2d637ec2b} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 13.02 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40310) (comment: 03214_backup_and_clear_old_temporary_directories.sh) (query 1, line 1) (in query: RESTORE TABLE default.mt_250_parts AS manyparts FROM Disk('backups', 'test_11/mt_250_parts.zip') SETTINGS allow_different_table_def=true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b2ceca 11. ./build_docker/./src/IO/ReadBufferFromFileBase.cpp:17: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x0000000023b2c424 12. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:232: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd557 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 14. ./build_docker/./src/Backups/BackupImpl.cpp:743: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf8695b 15. ./build_docker/./src/Backups/BackupImpl.cpp:868: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf880d8 16. ./build_docker/./src/Backups/BackupImpl.cpp:798: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf87a85 17. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6098: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x0000000030d186c7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6041: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d74096 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c03579a 20. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:18:57.435404 [ 5732 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 13.02 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b2ceca 11. ./build_docker/./src/IO/ReadBufferFromFileBase.cpp:17: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x0000000023b2c424 12. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:232: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd557 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 14. ./build_docker/./src/Backups/BackupImpl.cpp:743: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf8695b 15. ./build_docker/./src/Backups/BackupImpl.cpp:868: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf880d8 16. ./build_docker/./src/Backups/BackupImpl.cpp:798: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf87a85 17. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6098: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x0000000030d186c7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6041: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d74096 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c03579a 20. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (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&&) @ 0x000000002c034e79 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c027cee 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:1169: DB::RestorerFromBackup::runDataRestoreTasks() @ 0x000000002c0278db 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:177: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c021279 8. ./build_docker/./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&) @ 0x000000002bf4f389 9. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 10. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf47eb4 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476c8 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:57.672978 [ 6249 ] {72ea9bd8-f652-49ad-ac34-02e2e6742e91} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x000000001f1588fb 6. 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 @ 0x000000001f2e526f 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f2e4e83 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001f2e4c2a 9. 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&&) @ 0x000000001f2d5b5f 10. 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 @ 0x000000001f1d1632 11. 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&&) @ 0x000000001f1d107f 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f1cbfe3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f1c8b0b 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:18:57.690333 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x000000001f1588fb 6. 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 @ 0x000000001f2e526f 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f2e4e83 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001f2e4c2a 9. 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&&) @ 0x000000001f2d5b5f 10. 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 @ 0x000000001f1d1632 11. 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&&) @ 0x000000001f1d107f 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f1cbfe3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f1c8b0b 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:57.822438 [ 4938 ] {73989a90-013a-4d56-8ae0-fed4104ff2bd} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(sumState(0), CAST(1, 'Int8')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 122, line 426) (in query: SELECT arrayReduce(sumState(0),CAST(1 AS Int8));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:57.828820 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(sumState(0), CAST(1, 'Int8')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:58.267391 [ 4938 ] {c0d775b2-b307-48cf-a43f-bca7531b1eb7} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 125, line 429) (in query: SELECT runningDifference(CAST( 0 AS Nullable(Int8)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:58.290924 [ 4938 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000002077477d 6. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002aceb295 7. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002ace825e 8. std::function (std::shared_ptr)>::operator()(std::shared_ptr) const @ 0x000000002ace8e35 9. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002ace74a8 10. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002ace7eda 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38a7a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:18:58.306479 [ 6022 ] {} DynamicQueryHandler: Code: 516. DB::Exception: header_test: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:58.540088 [ 5382 ] {} DynamicQueryHandler: Code: 516. DB::Exception: Got an empty user name from X-ClickHouse HTTP headers. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:47: DB::(anonymous namespace)::checkUserNameNotEmpty(String const&, std::basic_string_view>) @ 0x000000003170b515 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:119: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003170820f 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:58.937171 [ 4938 ] {800583d0-88a6-4e49-a521-cf89c45ef303} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 130, line 434) (in query: SELECT uniqUpToArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:58.957262 [ 4938 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.072538 [ 4938 ] {bcf44df2-cb6b-42b8-b11f-27cb4aa322c6} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 131, line 435) (in query: SELECT uniqCombinedArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.090794 [ 4938 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.200461 [ 4938 ] {d76de8d7-406c-4061-8864-951eb74d585e} executeQuery: Code: 46. DB::Exception: Function with name `uniqCombinedBiasCorrectedArray` does not exist. In scope SELECT uniqCombinedBiasCorrectedArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 132, line 436) (in query: SELECT uniqCombinedBiasCorrectedArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.211547 [ 4938 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqCombinedBiasCorrectedArray` does not exist. In scope SELECT uniqCombinedBiasCorrectedArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.237101 [ 6249 ] {88d3e12d-b571-4ecc-92fc-4f1ba319b9ed} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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*) @ 0x000000001fc7a845 6. 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 @ 0x000000001fe2f092 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe2e8c3 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001fe2e66a 9. 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&&) @ 0x000000001fe2d3bc 10. 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 @ 0x000000001fd14272 11. 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&&) @ 0x000000001fd13cbf 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:18:59.241336 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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*) @ 0x000000001fc7a845 6. 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 @ 0x000000001fe2f092 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe2e8c3 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001fe2e66a 9. 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&&) @ 0x000000001fe2d3bc 10. 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 @ 0x000000001fd14272 11. 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&&) @ 0x000000001fd13cbf 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.313226 [ 4938 ] {8fb0181e-4677-4f54-bd61-550cb583aa31} executeQuery: Code: 46. DB::Exception: Function with name `uniqCombinedLinearCountingArray` does not exist. In scope SELECT uniqCombinedLinearCountingArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 133, line 437) (in query: SELECT uniqCombinedLinearCountingArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.322689 [ 4938 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqCombinedLinearCountingArray` does not exist. In scope SELECT uniqCombinedLinearCountingArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.342942 [ 6951 ] {test_15_1752365938_02883_q1} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `sub` in scope SELECT * FROM system.numbers WHERE number IN (sub). Maybe you meant: ['sub']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44128) (comment: 02483_elapsed_time.sh) (query 1, line 1) (in query: WITH ( SELECT sleepEachRow(1) ) AS sub SELECT * FROM ( SELECT * FROM system.numbers WHERE number IN (sub) ) SETTINGS enable_global_with_statement = 0, enable_analyzer = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.366644 [ 6951 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `sub` in scope SELECT * FROM system.numbers WHERE number IN (sub). Maybe you meant: ['sub']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.390016 [ 6022 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database header_test does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5f7b3e 6. ./build_docker/./src/Interpreters/Context.cpp:2804: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002d485e35 7. ./build_docker/./src/Interpreters/Context.cpp:2812: DB::Context::setCurrentDatabase(String const&) @ 0x000000002d494eae 8. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315be515 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:59.448216 [ 4938 ] {c39ba69e-d047-48f2-bef0-757407a598c3} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 134, line 438) (in query: SELECT uniqExactArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.466989 [ 4938 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.510003 [ 6070 ] {969079c6-7fa8-4b05-801c-d547d74a7182} executeQuery: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_79lmiw27.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44150) (comment: 02130_parse_quoted_null.sh) (query 1, line 1) (in query: select * from file('test_79lmiw27.data', 'CustomSeparated', 'x Nullable(Float64), y Nullable(UInt64)') settings input_format_parallel_parsing=0, format_custom_escaping_rule='Quoted'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:530: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x000000002c5fb30e 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002c5f45bc 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5f136b 8. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:117: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000003173015a 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003197cdb4 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303ea300 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.533666 [ 6070 ] {} TCPHandler: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_79lmiw27.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:530: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x000000002c5fb30e 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002c5f45bc 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5f136b 8. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:117: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000003173015a 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003197cdb4 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303ea300 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.596778 [ 4938 ] {c5eb3d9f-f9ec-4816-b2db-96a6375e4489} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 135, line 439) (in query: SELECT COVAR_POPArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.607969 [ 4938 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.737136 [ 4938 ] {eec774db-7551-4efe-a92d-8e7397c3c56f} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 136, line 440) (in query: SELECT COVAR_SAMPArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.744321 [ 4938 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002acedd7c 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x000000002d6c6380 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: 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 @ 0x000000002d6c79f5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.775992 [ 6126 ] {61518865-b6a3-4278-a077-1afff9b1812e} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60404) (comment: 01399_http_request_headers.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x0000000031732fda 6. ./build_docker/./src/Formats/FormatFactory.cpp:554: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000031738ced 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4d2a 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.816143 [ 6126 ] {61518865-b6a3-4278-a077-1afff9b1812e} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x0000000031732fda 6. ./build_docker/./src/Formats/FormatFactory.cpp:590: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000031739c49 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1728: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x000000002e2b8cd5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1907: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b5fd0 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.821771 [ 6126 ] {61518865-b6a3-4278-a077-1afff9b1812e} DynamicQueryHandler: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x0000000031732fda 6. ./build_docker/./src/Formats/FormatFactory.cpp:554: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000031738ced 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4d2a 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:59.841648 [ 5478 ] {6e27f5be-4680-43b1-ad5b-6c8d1a66ba95} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(count(), 0_UInt8) :: 1) -> throwIf(equals(count(), 0_UInt8)) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50150) (comment: 02446_parent_zero_copy_locks.sql) (query 23, line 39) (in query: -- wait for outdated parts to be removed (do not ignore _state column, so it will count Deleting parts as well) select throwIf(count() = 0), groupArray(_state) from ( select *, _state from system.parts where database=currentDatabase() and table like 'rmt%' and active=0 ) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.867331 [ 5478 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(count(), 0_UInt8) :: 1) -> throwIf(equals(count(), 0_UInt8)) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:18:59.993754 [ 4938 ] {1800e85f-085b-49de-ad51-fb618415389c} executeQuery: Code: 43. DB::Exception: Second argument (weight) for function quantileTimingWeighted must be unsigned integer, but it has type Int8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 137, line 441) (in query: SELECT medianTimingWeightedArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. ./src/AggregateFunctions/AggregateFunctionQuantile.h:98: DB::AggregateFunctionQuantile<_BitInt(8), DB::QuantileTiming, DB::NameQuantileTimingWeighted, true, float, false, false>::AggregateFunctionQuantile(std::vector, std::vector::allocator> const&, DB::Array const&) @ 0x000000002551e5f4 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: _ZNSt3__120__shared_ptr_emplaceIN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEEC2B8ne190107IJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISG_EEEERKNS1_5ArrayEES9_TnNS_9enable_ifIXntsr7is_sameINT0_10value_typeENS_19__for_overwrite_tagEEE5valueEiE4typeELi0EEES9_DpOT_ @ 0x000000002551dc99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: _ZNSt3__115allocate_sharedB8ne190107IN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISE_EEEERKNS1_5ArrayEETnNS_9enable_ifIXntsr8is_arrayIT_EE5valueEiE4typeELi0EEENSB_ISN_EERKT0_DpOT1_ @ 0x000000002551daa6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025504523 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:19:00.010011 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (weight) for function quantileTimingWeighted must be unsigned integer, but it has type Int8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. ./src/AggregateFunctions/AggregateFunctionQuantile.h:98: DB::AggregateFunctionQuantile<_BitInt(8), DB::QuantileTiming, DB::NameQuantileTimingWeighted, true, float, false, false>::AggregateFunctionQuantile(std::vector, std::vector::allocator> const&, DB::Array const&) @ 0x000000002551e5f4 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: _ZNSt3__120__shared_ptr_emplaceIN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEEC2B8ne190107IJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISG_EEEERKNS1_5ArrayEES9_TnNS_9enable_ifIXntsr7is_sameINT0_10value_typeENS_19__for_overwrite_tagEEE5valueEiE4typeELi0EEES9_DpOT_ @ 0x000000002551dc99 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: _ZNSt3__115allocate_sharedB8ne190107IN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISE_EEEERKNS1_5ArrayEETnNS_9enable_ifIXntsr8is_arrayIT_EE5valueEiE4typeELi0EEENSB_ISN_EERKT0_DpOT1_ @ 0x000000002551daa6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025504523 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:19:00.244086 [ 4938 ] {9dd6f82c-a617-40ca-9c92-cb8c847c0e4e} executeQuery: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 138, line 442) (in query: SELECT quantilesDeterministicArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int32)]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/AggregateFunctions/QuantilesCommon.h:47: DB::QuantileLevels::QuantileLevels(DB::Array const&, bool) @ 0x0000000024b794ce 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:87: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000024bc7994 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:19:00.266499 [ 4938 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/AggregateFunctions/QuantilesCommon.h:47: DB::QuantileLevels::QuantileLevels(DB::Array const&, bool) @ 0x0000000024b794ce 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:87: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000024bc7994 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:19:00.455616 [ 4938 ] {b59f1146-63a5-4397-9025-ae6d60c54ce3} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersections. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 139, line 444) (in query: SELECT maxIntersections([], []);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:201: DB::(anonymous namespace)::createAggregateFunctionMaxIntersections(DB::(anonymous namespace)::AggregateFunctionIntersectionsKind, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000027b8906f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:00.473082 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersections. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:201: DB::(anonymous namespace)::createAggregateFunctionMaxIntersections(DB::(anonymous namespace)::AggregateFunctionIntersectionsKind, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000027b8906f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:00.584117 [ 4938 ] {6f87f259-53f5-49c3-965d-37d50843b9fa} executeQuery: Code: 43. DB::Exception: Illegal type Nothing of argument for aggregate function sum. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 140, line 445) (in query: SELECT sumMap([], []);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./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*) @ 0x00000000268f8857 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:00.593036 [ 4938 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nothing of argument for aggregate function sum. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./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*) @ 0x00000000268f8857 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:00.816228 [ 6126 ] {125caa4e-510d-4bf6-9f09-737beb058b9a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42912) (comment: 02302_lc_nullable_string_insert_as_number.sql) (in query: DROP DATABASE IF EXISTS test_wkb4hxeq SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:00.819136 [ 6126 ] {125caa4e-510d-4bf6-9f09-737beb058b9a} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:00.942639 [ 6249 ] {ec14bd63-a8b5-44c3-884e-5353daae42f6} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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*) @ 0x000000001fb9c138 6. 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 @ 0x000000001fd22275 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd21c43 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001fd219ea 9. 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&&) @ 0x000000001fd14c5f 10. 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&&) @ 0x000000001fd137c1 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 13. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:00.943016 [ 4938 ] {3e6441d8-d162-4ea9-9a12-d5802e5bd27c} executeQuery: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38610) (comment: 00534_filimonov.sh) (query 141, line 447) (in query: SELECT countArray();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionArray.cpp:29: DB::(anonymous namespace)::AggregateFunctionCombinatorArray::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000002827803c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8468 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:00.948181 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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*) @ 0x000000001fb9c138 6. 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 @ 0x000000001fd22275 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd21c43 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001fd219ea 9. 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&&) @ 0x000000001fd14c5f 10. 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&&) @ 0x000000001fd137c1 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 13. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:00.965739 [ 4938 ] {} TCPHandler: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionArray.cpp:29: DB::(anonymous namespace)::AggregateFunctionCombinatorArray::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000002827803c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8468 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.113759 [ 3900 ] {a3d5c934-b38d-4218-942c-b35a5559583b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41512) (comment: 02483_elapsed_time.sh) (query 1, line 1) (in query: SELECT `__table1`.`type` = 'ExceptionBeforeStart' AS `expected_type`, `__table1`.`query_duration_ms` <= 1000 AS `elapsed_more_than_one_second` FROM `system`.`query_log` AS `__table1` WHERE (`__table1`.`current_database` = 'test_15') AND (`__table1`.`query_id` = 'test_15_1752365938_02883_q1')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.120574 [ 3900 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.218967 [ 5103 ] {ccc783fb-e162-4bcb-9737-4cc0aad8a8a8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44256) (comment: 02483_elapsed_time.sh) (query 1, line 1) (in query: SELECT type == 'ExceptionBeforeStart' as expected_type, query_duration_ms <= 1000 as elapsed_more_than_one_second FROM system.query_log WHERE current_database = 'test_15' AND query_id='test_15_1752365938_02883_q1'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:19:01.220729 [ 5072 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55546, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:01.221230 [ 5072 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55546, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:01.241263 [ 5103 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.289213 [ 6126 ] {74892250-c39e-476a-9c37-7f917bb53e06} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38128): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38128) (comment: 02483_elapsed_time.sh) (query 1, line 1) (in query: SELECT `__table1`.`type` = 'ExceptionBeforeStart' AS `expected_type`, `__table1`.`query_duration_ms` <= 1000 AS `elapsed_more_than_one_second` FROM `system`.`query_log` AS `__table1` WHERE (`__table1`.`current_database` = 'test_15') AND (`__table1`.`query_id` = 'test_15_1752365938_02883_q1')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:654: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x00000000316df753 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f8ae32 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f85802 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:152: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221de7c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.301005 [ 6126 ] {} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38128): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:654: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x00000000316df753 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f8ae32 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f85802 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:152: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221de7c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.636150 [ 6249 ] {a92fe429-f437-4cbf-9f2a-29844f45c4d7} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. long DB::impl_::DecimalBinaryOperation, true>::applyScaledDiv(long, long, long) @ 0x000000001a09050d 6. 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) @ 0x000000001a091237 7. 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*) @ 0x000000001a090f4b 8. 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 @ 0x000000001a44040a 9. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43fcc3 10. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43fa6a 11. 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&&) @ 0x000000001a4328ff 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a431461 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:19:01.651102 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. long DB::impl_::DecimalBinaryOperation, true>::applyScaledDiv(long, long, long) @ 0x000000001a09050d 6. 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) @ 0x000000001a091237 7. 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*) @ 0x000000001a090f4b 8. 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 @ 0x000000001a44040a 9. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43fcc3 10. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43fa6a 11. 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&&) @ 0x000000001a4328ff 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a431461 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.844297 [ 5379 ] {ee43b95e-8278-434f-97e5-b8d75376097d} executeQuery: Code: 36. DB::Exception: Column `path` should not be empty. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:156: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba7d1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:01.847271 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:156: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba7d1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.009180 [ 5379 ] {d4b96ad2-43d7-4b4f-984f-35f95cf4023a} executeQuery: Code: 36. DB::Exception: Column `name` should not be empty. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba6d1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.013677 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba6d1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.142483 [ 5379 ] {1a4d2138-c5d9-463d-aba7-94d62ad663e2} executeQuery: Code: 44. DB::Exception: Cannot insert column version, because it is MATERIALIZED column. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:248: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000002dce6ad4 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002dce5975 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf106e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.148753 [ 5380 ] {9f90f7e2-8d2f-4dbb-a1bb-1397baf32f76} executeQuery: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44236) (comment: 01745_alter_delete_view.sql) (query 7, line 23) (in query: ALTER TABLE test_view DELETE WHERE pk = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000003031e9e8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cbd6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.167045 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:248: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000002dce6ad4 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002dce5975 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf106e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.168843 [ 5380 ] {} TCPHandler: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000003031e9e8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cbd6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.291494 [ 3774 ] {f1635aa7-ae74-4316-bb37-82fe9ad4eb2f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42968) (comment: 02446_parent_zero_copy_locks.sql) (in query: DROP DATABASE IF EXISTS test_fidaeu5w SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.293926 [ 3774 ] {f1635aa7-ae74-4316-bb37-82fe9ad4eb2f} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:02.302777 [ 5379 ] {2b0ae6d2-8080-439f-a3d2-8e1fb2ed5de7} executeQuery: Code: 16. DB::Exception: No such column versionxyz in table system.zookeeper (a5eb14b3-b256-4962-8ef0-b7367c179538). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000002dce6bef 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002dce5975 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf106e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.307122 [ 5379 ] {} TCPHandler: Code: 16. DB::Exception: No such column versionxyz in table system.zookeeper (a5eb14b3-b256-4962-8ef0-b7367c179538). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000002dce6bef 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002dce5975 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf106e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.607881 [ 5379 ] {aa503582-40db-4ce0-a5fd-821429e81f10} executeQuery: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba751 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.611705 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba751 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.849803 [ 5379 ] {367ff6d0-ae83-4a02-9a85-446585c4ef1b} executeQuery: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba751 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.852205 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba751 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.974519 [ 5379 ] {66483a9c-6ca0-4c8b-9df8-c4d7897fd6f6} executeQuery: Code: 36. DB::Exception: Column `name` should not be empty. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba6d1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:02.978549 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba6d1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:03.256359 [ 5379 ] {3fd37238-3941-4d0f-8909-2be8c006f1be} executeQuery: Code: 36. DB::Exception: Sum of `name` length and `path` length should not exceed PATH_MAX. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:161: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba851 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:03.340607 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/System/StorageSystemZooKeeper.cpp:161: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x00000000288ba851 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 13. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 14. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 15. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:19:03.495114 [ 6249 ] {6c8fdbca-6e22-48a6-95a9-9ac6632a8ce8} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08d356 6. 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 @ 0x000000001a43f95c 7. 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 @ 0x000000001a43ea5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43e7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43e54a 10. 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&&) @ 0x000000001a4328bf 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:03.500928 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08d356 6. 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 @ 0x000000001a43f95c 7. 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 @ 0x000000001a43ea5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43e7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43e54a 10. 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&&) @ 0x000000001a4328bf 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:03.720371 [ 6249 ] {ee5fd7de-6b06-4e00-95a1-acd99ef432bc} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a073a98 6. 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 @ 0x000000001a440e67 7. 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 @ 0x000000001a4401ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43fcc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43fa6a 10. 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&&) @ 0x000000001a4328ff 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:03.745060 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a073a98 6. 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 @ 0x000000001a440e67 7. 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 @ 0x000000001a4401ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43fcc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43fa6a 10. 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&&) @ 0x000000001a4328ff 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:03.978212 [ 6249 ] {529d2a7f-2cfc-46fd-8ca2-8d4cf8c3cd08} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093b61 7. 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 @ 0x000000001a44189a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4411e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a440f8a 10. 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&&) @ 0x000000001a43293f 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:03.984174 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093b61 7. 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 @ 0x000000001a44189a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4411e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a440f8a 10. 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&&) @ 0x000000001a43293f 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.054131 [ 6249 ] {4bd0abc9-bc33-4a26-b22a-770113c3de1b} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08d356 6. 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 @ 0x000000001a43f95c 7. 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 @ 0x000000001a43ea5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43e7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43e54a 10. 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&&) @ 0x000000001a4328bf 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.061008 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08d356 6. 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 @ 0x000000001a43f95c 7. 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 @ 0x000000001a43ea5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43e7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43e54a 10. 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&&) @ 0x000000001a4328bf 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.121623 [ 6249 ] {29d97c53-b425-4084-b073-04021cd431e2} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a073a98 6. 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 @ 0x000000001a440e67 7. 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 @ 0x000000001a4401ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43fcc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43fa6a 10. 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&&) @ 0x000000001a4328ff 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.126799 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a073a98 6. 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 @ 0x000000001a440e67 7. 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 @ 0x000000001a4401ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43fcc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43fa6a 10. 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&&) @ 0x000000001a4328ff 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.182102 [ 6249 ] {a81f19c7-fd52-4d04-bf9e-ce4eaf4b205c} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093b61 7. 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 @ 0x000000001a44189a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4411e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a440f8a 10. 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&&) @ 0x000000001a43293f 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.188537 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093b61 7. 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 @ 0x000000001a44189a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4411e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a440f8a 10. 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&&) @ 0x000000001a43293f 11. 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&&) @ 0x000000001a431461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:19:04.348570 [ 6249 ] {74a88a4b-74e7-4206-b047-f0af6e45dbbd} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08d356 6. 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 @ 0x000000001a53895b 7. _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000001a53e953 8. 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 @ 0x000000001a53e6c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001a53e46a 10. 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&&) @ 0x000000001a5367dc 11. 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 @ 0x000000001a431eb2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43191f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:04.365190 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08d356 6. 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 @ 0x000000001a53895b 7. _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000001a53e953 8. 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 @ 0x000000001a53e6c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001a53e46a 10. 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&&) @ 0x000000001a5367dc 11. 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 @ 0x000000001a431eb2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43191f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:04.502715 [ 6249 ] {c538b972-2a5b-48c4-a45e-39c98e156db7} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a073a98 6. 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 @ 0x000000001a550440 7. 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 @ 0x000000001a558870 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a5585c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a55836a 10. 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&&) @ 0x000000001a54e3bc 11. 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 @ 0x000000001a431f12 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43195f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:04.519967 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a073a98 6. 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 @ 0x000000001a550440 7. 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 @ 0x000000001a558870 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a5585c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a55836a 10. 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&&) @ 0x000000001a54e3bc 11. 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 @ 0x000000001a431f12 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43195f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:04.697134 [ 6249 ] {bedb6c47-8508-42ad-86b5-9adfff390021} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093a01 6. 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 @ 0x000000001a567f3b 7. 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 @ 0x000000001a57219c 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a571ea3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a571c4a 10. 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&&) @ 0x000000001a565cfc 11. 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 @ 0x000000001a431f72 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43199f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:04.706220 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a093a01 6. 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 @ 0x000000001a567f3b 7. 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 @ 0x000000001a57219c 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a571ea3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a571c4a 10. 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&&) @ 0x000000001a565cfc 11. 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 @ 0x000000001a431f72 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43199f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42c8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42a82c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a428ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:05.620179 [ 6249 ] {8b9f744f-8041-475d-a105-3bbe347426e0} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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 @ 0x000000001a612d9e 6. 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&&) @ 0x000000001a61007f 7. 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 @ 0x000000001a5ebbb2 8. 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&&) @ 0x000000001a5eb5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5ea468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06dd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:05.628685 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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 @ 0x000000001a612d9e 6. 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&&) @ 0x000000001a61007f 7. 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 @ 0x000000001a5ebbb2 8. 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&&) @ 0x000000001a5eb5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5ea468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06dd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:06.086943 [ 6249 ] {b419925b-11cf-4fd6-a8fe-50d64f0a3451} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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 @ 0x000000001a612d9e 6. 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&&) @ 0x000000001a61007f 7. 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 @ 0x000000001a5ebbb2 8. 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&&) @ 0x000000001a5eb5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5ea468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06dd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:06.090320 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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 @ 0x000000001a612d9e 6. 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&&) @ 0x000000001a61007f 7. 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 @ 0x000000001a5ebbb2 8. 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&&) @ 0x000000001a5eb5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5ea468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06dd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:06.812103 [ 3900 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:19:06.947084 [ 3900 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:19:07.091489 [ 7056 ] {7e09a62d-1374-46db-90cd-b9aaa1dc89bf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43096) (comment: 02423_insert_summary_behaviour.sh) (in query: DROP DATABASE IF EXISTS test_qwbfubde SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:07.105669 [ 7056 ] {7e09a62d-1374-46db-90cd-b9aaa1dc89bf} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:07.183536 [ 3900 ] {c576c1da-9bde-41e9-82b9-46ee650e7f35} executeQuery: Code: 60. DB::Exception: Table test_3ig7ipwc.t_json_6 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44676) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: INSERT INTO t_json_6 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:19:07.210719 [ 3900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3ig7ipwc.t_json_6 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:19:07.662261 [ 6024 ] {eaf47a54-8756-413f-89bd-cbbb5bb45747} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT DISTINCT toTypeName(data) FROM t_json_6. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44716) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: SELECT DISTINCT toTypeName(data) FROM t_json_6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:19:07.698511 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT DISTINCT toTypeName(data) FROM t_json_6. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:19:08.081798 [ 6070 ] {685536dc-b132-4632-9421-177aa5840641} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44828) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:19:08.089962 [ 6070 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:19:08.484077 [ 5380 ] {b78e66d8-a960-45f9-9d8c-b18223dfa994} executeQuery: Code: 60. DB::Exception: Table test_3ig7ipwc.t_json_6 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44860) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: DROP TABLE t_json_6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:08.504038 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3ig7ipwc.t_json_6 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:08.775595 [ 6249 ] {32d59eea-ffb8-43e0-9512-d7e119f87d79} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44890) (comment: 03358_lambda_resolution_segfault_analyzer.sql) (query 2, line 2) (in query: WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc54899 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05415 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:08.780887 [ 6249 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc54899 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05415 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:10.016536 [ 5732 ] {85c56a51-4a2e-4f49-b314-e6e88535a938} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `ns` in scope SELECT count(), sum(ns) FROM (SELECT intDiv(number, NULL) AS k FROM system.numbers_mt GROUP BY k) ARRAY JOIN ns. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55764) (comment: 01538_fuzz_aggregate.sql) (query 1, line 1) (in query: SELECT count(), sum(ns) FROM ( SELECT intDiv(number, NULL) AS k FROM system.numbers_mt GROUP BY k ) ARRAY JOIN ns;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5a903 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b255 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:10.022556 [ 5732 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `ns` in scope SELECT count(), sum(ns) FROM (SELECT intDiv(number, NULL) AS k FROM system.numbers_mt GROUP BY k) ARRAY JOIN ns. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5a903 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b255 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:10.395286 [ 4694 ] {c4be0e67-7f6c-4991-b09b-ce10e51a15d9} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02008_test_union_distinct_in_subquery.sql) (in query: /* ddl_entry=query-0000000024 */ CREATE TABLE test_5.test UUID '17def252-e4fc-4ccc-a656-d879ec616fe2' (`name` String, `uuid` UUID) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:10.482529 [ 4694 ] {c4be0e67-7f6c-4991-b09b-ce10e51a15d9} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55780) (comment: 02008_test_union_distinct_in_subquery.sql) (query 2, line 2) (in query: create table test (name String, uuid UUID) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:10.488189 [ 4694 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.027278 [ 7056 ] {00964ca5-33a0-4f5b-a3b1-2f125a718632} executeQuery: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55846) (comment: 02475_analysis_of_variance.sql) (query 4, line 5) (in query: SELECT analysisOfVariance(1.11, -20);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000282306c0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.033665 [ 7056 ] {} TCPHandler: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000282306c0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.192640 [ 7056 ] {15301e6c-10d8-42d3-876f-60ced26b1b5c} executeQuery: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55846) (comment: 02475_analysis_of_variance.sql) (query 5, line 6) (in query: SELECT analysisOfVariance(1.11, 20 :: UInt128);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000282306c0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.196619 [ 7056 ] {} TCPHandler: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000282306c0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.373127 [ 7056 ] {dfc0b7d3-82ab-40cc-9088-54e408fe353c} executeQuery: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 9000000000000001): While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55846) (comment: 02475_analysis_of_variance.sql) (query 6, line 7) (in query: SELECT analysisOfVariance(1.11, 9000000000000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./src/AggregateFunctions/Moments.h:452: DB::AnalysisOfVarianceMoments::resizeIfNeeded(unsigned long) @ 0x0000000028235d12 6. ./src/AggregateFunctions/Moments.h:466: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x000000002823592c 7. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000282332dc 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6c2dd2 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6c3604 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7a7d 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.381774 [ 7056 ] {} TCPHandler: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 9000000000000001): While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./src/AggregateFunctions/Moments.h:452: DB::AnalysisOfVarianceMoments::resizeIfNeeded(unsigned long) @ 0x0000000028235d12 6. ./src/AggregateFunctions/Moments.h:466: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x000000002823592c 7. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000282332dc 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6c2dd2 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6c3604 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7a7d 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.720089 [ 3863 ] {2617c054-289b-4b18-8337-fe64e25a07c8} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_7_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56000) (comment: 02305_schema_inference_with_globs.sh) (query 1, line 1) (in query: desc file('02305_schema_inference_with_globs_test_7_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=8, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c95db 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284c882e 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 11. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.748297 [ 3863 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_7_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c95db 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284c882e 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 11. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:11.986826 [ 3863 ] {0c327480-7855-4f76-a19c-80713a2e5a35} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47256) (comment: 02999_scalar_subqueries_bug_1.sql) (in query: DROP DATABASE IF EXISTS test_p9gnyj3r SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:12.006368 [ 3863 ] {0c327480-7855-4f76-a19c-80713a2e5a35} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:12.134393 [ 5380 ] {6ce34509-69be-4cf7-bd1b-f5e0ec6ef31b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47266) (comment: 02999_scalar_subqueries_bug_1.sql) (in query: DROP DATABASE IF EXISTS test_p9gnyj3r SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:12.144995 [ 5380 ] {6ce34509-69be-4cf7-bd1b-f5e0ec6ef31b} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:12.161564 [ 7056 ] {7807735f-e436-4616-b8cb-d4764c123657} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_7_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56076) (comment: 02305_schema_inference_with_globs.sh) (query 1, line 1) (in query: desc file('02305_schema_inference_with_globs_test_7_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=16, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c9751 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284c882e 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 11. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:12.200000 [ 7056 ] {} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_7_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c9751 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284c882e 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 11. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:12.595707 [ 4938 ] {738a9a50-f606-40a8-874e-b028d5b22d33} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_7_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56146) (comment: 02305_schema_inference_with_globs.sh) (query 1, line 1) (in query: desc file('02305_schema_inference_with_globs_test_7_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=24, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c9751 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284c882e 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 11. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:12.621816 [ 4938 ] {} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20372.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_7_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c9751 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284c882e 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 11. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:13.758885 [ 4938 ] {8292f12c-ed65-4c05-a6db-6bb6eabbaa90} executeQuery: Code: 57. DB::Exception: Table test_ny911sz3.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56162) (comment: 01845_add_testcase_for_arrayElement.sql) (query 8, line 11) (in query: CREATE TABLE test (`key` UInt32, `arr` ALIAS [1, 2]) ENGINE = MergeTree PARTITION BY tuple() ORDER BY tuple() SETTINGS index_granularity = 36615, min_bytes_for_wide_part = 1073741824, 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 = 133650409, compact_parts_max_bytes_to_buffer = 360564475, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27683099, merge_max_block_size = 2840, 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 = 9301642392, index_granularity_bytes = 23468704, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 30, 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 = 66380, primary_key_compress_block_size = 25156, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:13.828484 [ 4938 ] {} TCPHandler: Code: 57. DB::Exception: Table test_ny911sz3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:14.381813 [ 3901 ] {02c4aa95-a372-4718-a22d-84d182eb5931} executeQuery: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56204) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/Planner.cpp:1532: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79de7 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:14.392383 [ 3901 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/Planner.cpp:1532: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79de7 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:19:16.245898 [ 5971 ] {d055c984-0baf-402f-badb-88df78ee3b4a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1041.027653 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49936) (comment: 02293_http_header_full_summary_without_progress.sh) (in query: SELECT 1 + sleepEachRow(0.00002) FROM numbers(100000) ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000002d63c54f 5. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def371c 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:16.254499 [ 5971 ] {d055c984-0baf-402f-badb-88df78ee3b4a} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1041.027653 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000002d63c54f 5. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def371c 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:17.572128 [ 3885 ] {fb1d8d87-8c0b-47ac-967d-f519e81a9f6b} executeQuery: Code: 57. DB::Exception: Table test_1.local_01099_a already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56114) (comment: 01099_parallel_distributed_insert_select.sql) (query 35, line 67) (in query: CREATE TABLE local_01099_a (number UInt64) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:17.592209 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.local_01099_a already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:18.774589 [ 5379 ] {dc428f0a-decf-4d44-9ffe-6e8e5150dd50} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=835). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56666) (comment: 01010_partial_merge_join_negative.sql) (query 10, line 14) (in query: SELECT * FROM t0 FULL JOIN t1 ON t1.x = t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:18.795701 [ 5379 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=835). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:19.080249 [ 5971 ] {559d7993-194d-49f8-814a-09dc642a9422} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/3d0/3d049d24-e768-49e5-86e7-b4346f32861f//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56810) (comment: 00832_storage_file_lock.sql) (query 3, line 3) (in query: SELECT * FROM file;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000303ef031 6. ./build_docker/./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) @ 0x000000002ddac77e 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 8. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:19.085322 [ 5971 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/3d0/3d049d24-e768-49e5-86e7-b4346f32861f//data.TSV doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000303ef031 6. ./build_docker/./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) @ 0x000000002ddac77e 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 8. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:20.685643 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:21.073326 [ 3863 ] {499da95e-bb3a-4d48-98f6-28924c5d02ef} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48734) (comment: 00621_regression_for_in_operator.sql) (in query: DROP DATABASE IF EXISTS test_4nk48pog SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:21.074723 [ 3863 ] {499da95e-bb3a-4d48-98f6-28924c5d02ef} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:22.562825 [ 5971 ] {63e55620-176f-4bba-ad50-def14aa023c4} 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.3.20372.altinityantalya (altinity build)) (from [::1]:47232) (comment: 02184_storage_add_support_ttl.sql) (query 4, line 4) (in query: DETACH TABLE mergeTree_02184;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c782add 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:22.569661 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c782add 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:22.735479 [ 6951 ] {2e2b8dfe-faf3-4909-a265-240222fb53f0} executeQuery: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56338) (comment: 01018_Distributed__shard_num.sql) (query 42, line 72) (in query: SELECT _shard_num, key, b.host_name, b.host_address IN ('::1', '127.0.0.1'), b.port FROM dist_1 a JOIN system.clusters b ON _shard_num = b.shard_num WHERE b.cluster = 'test_cluster_two_shards_localhost' ORDER BY key SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032147791 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Planner/Planner.cpp:251: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd727a9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:19:22.749552 [ 6951 ] {} TCPHandler: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032147791 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Planner/Planner.cpp:251: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd727a9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:19:24.429448 [ 4938 ] {4b83aafa-7afc-43f8-82fc-68fe92b542c3} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.19 MiB (attempt to allocate chunk of 1.06 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47404) (comment: 02896_leading_zeroes_no_octal.sql) (query 11, line 14) (in query: INSERT INTO t_leading_zeroes VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 25. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 30. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 2025.07.13 02:19:24.464726 [ 4938 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.19 MiB (attempt to allocate chunk of 1.06 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 25. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 30. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 2025.07.13 02:19:25.037431 [ 3885 ] {7bd039eb-9140-4f2f-8d34-83080a5bfaee} executeQuery: Code: 57. DB::Exception: Table test_7.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47586) (comment: 02367_analyzer_table_alias_columns.sql) (query 7, line 17) (in query: CREATE TABLE test_table (`id` UInt64, `value` String, `alias_value` ALIAS ((id + 1) AS inside_value) + inside_value) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 51850, min_bytes_for_wide_part = 56228629, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 74, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 392048530, compact_parts_max_granules_to_buffer = 18, compact_parts_merge_max_bytes_to_prefetch_part = 24253940, merge_max_block_size = 11566, old_parts_lifetime = 420., 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 = 1714680, 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 = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 94500, primary_key_compress_block_size = 32637, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:25.058075 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:25.408308 [ 4468 ] {01154744-ca39-44b6-a550-70d79f8a9c01} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50308) (comment: 02377_optimize_sorting_by_input_stream_properties.sql) (query 6, line 7) (in query: SELECT `__table1`.`a` AS `a`, `__table1`.`b` AS `b` FROM `test_mws58ljb`.`optimize_sorting` AS `__table1` ORDER BY `__table1`.`a` ASC, `__table1`.`b` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:25.413655 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:25.466741 [ 3815 ] {24aee6ea-5179-4938-9230-4e8e5aacf1c8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47580) (comment: 02377_optimize_sorting_by_input_stream_properties.sql) (query 6, line 7) (in query: -- { echoOn } -- order by for MergeTree w/o sorting key SELECT a, b from optimize_sorting order by a, b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:19:25.470980 [ 4529 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42014, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:25.471933 [ 5480 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59432, local: [::ffff:127.0.0.9]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:25.472364 [ 4529 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42014, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:25.474880 [ 5480 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59432, local: [::ffff:127.0.0.9]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:25.493536 [ 3815 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:26.513119 [ 6126 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:44586, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:26.516685 [ 6126 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:44586, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:27.093396 [ 4477 ] {18411386-7e1b-4fda-976c-9859640c6d96} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47848) (comment: 02903_empty_order_by_throws_error.sh) (query 2, line 3) (in query: CREATE TABLE test_empty_order_by(a UInt8) ENGINE = MergeTree() SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:655: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311cb4a5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:19:27.113342 [ 4477 ] {} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:655: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311cb4a5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:19:27.160202 [ 3815 ] {899b43e1-59c0-4158-83c9-07393acca186} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47842) (comment: 03003_arrayEnumerate_crash.sql) (query 1, line 1) (in query: SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000022da58af 5. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000022da526c 6. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022dbe27a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:27.170954 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000022da58af 5. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000022da526c 6. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022dbe27a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:27.230219 [ 3815 ] {07e5ae17-57e5-48df-bac5-d4bf6ee235db} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47842) (comment: 03003_arrayEnumerate_crash.sql) (query 2, line 2) (in query: SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000022da58af 5. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000022da526c 6. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022dbe27a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:27.239515 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000022da58af 5. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000022da526c 6. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022dbe27a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:28.400346 [ 6024 ] {a17656d0-a44d-4b2e-9b0a-6276968e2de2} executeQuery: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47944) (comment: 02833_tuple_concat.sql) (query 1, line 1) (in query: SELECT tupleConcat();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020d033a4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:28.471269 [ 6024 ] {} TCPHandler: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020d033a4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:28.648918 [ 6126 ] {b81b5d30-b049-477d-a8f5-203702ea6db2} executeQuery: Code: 57. DB::Exception: Table test_99l353ig.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47930) (comment: 03311_subcolumns_in_default_and_materialized_expressions.sql) (query 7, line 9) (in query: create table test (t Tuple(a UInt32), json JSON(b UInt32), a UInt32 materialized t.a, b UInt32 materialized json.b, c UInt32 materialized json.c) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:28.667875 [ 6126 ] {} TCPHandler: Code: 57. DB::Exception: Table test_99l353ig.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:28.863624 [ 6024 ] {235aaf21-b3b0-49b1-97db-12cf82e8cfa0} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument 2 of function tupleConcat: In scope SELECT tupleConcat((1, 'y'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47944) (comment: 02833_tuple_concat.sql) (query 2, line 2) (in query: SELECT tupleConcat((1, 'y'), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020d032b7 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:28.888069 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument 2 of function tupleConcat: In scope SELECT tupleConcat((1, 'y'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionTupleConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020d032b7 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:29.977221 [ 3901 ] {d096a9c8-5308-4c92-bd22-9b8a6987c1fc} executeQuery: Code: 10. DB::Exception: Column `v2` not found in table test_7.mv_extra_columns_dst (4c50fce9-564c-4236-aa81-c2733c59ea4c). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47932) (comment: 01019_materialized_view_select_extra_columns.sql) (query 9, line 31) (in query: SELECT * FROM mv_extra_columns_view;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:215: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x00000000307e20ff 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:349: 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) @ 0x00000000321965c7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3c62a 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: 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 @ 0x0000000030e1dc66 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: 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 @ 0x0000000030e1d95c 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311d5934 11. ./build_docker/./src/Storages/StorageMaterializedView.cpp:362: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000304dfa14 12. ./build_docker/./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) @ 0x000000002ddac77e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:30.017592 [ 3901 ] {} TCPHandler: Code: 10. DB::Exception: Column `v2` not found in table test_7.mv_extra_columns_dst (4c50fce9-564c-4236-aa81-c2733c59ea4c). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:215: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x00000000307e20ff 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:349: 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) @ 0x00000000321965c7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3c62a 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: 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 @ 0x0000000030e1dc66 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: 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 @ 0x0000000030e1d95c 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311d5934 11. ./build_docker/./src/Storages/StorageMaterializedView.cpp:362: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000304dfa14 12. ./build_docker/./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) @ 0x000000002ddac77e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:30.091898 [ 7056 ] {3b3645bc-2804-403b-aafd-8f720c6aef4e} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: while executing 'FUNCTION toUInt64(val :: 0) -> toUInt64(__table1.val) LowCardinality(UInt64) : 2'. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43628) (comment: 02480_suspicious_lowcard_in_key.sql) (query 5, line 9) (in query: SELECT count() AS `count()` FROM `test_15`.`test` AS `__table1` WHERE toUInt64(`__table1`.`val`) = -1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/Functions/FunctionsConversion.h:1843: 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*) @ 0x000000002b0875aa 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b083246 7. ./src/Core/callOnTypeIndex.h:267: 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&&) @ 0x000000002b00eee5 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01c13e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01afa3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc823 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dcb897 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:19:30.153278 [ 10339 ] {fff5fecf-15e3-47cb-86ca-feebdab2a2de} executeQuery: Code: 70. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Unexpected inf or nan to integer conversion: while executing 'FUNCTION toUInt64(val :: 0) -> toUInt64(__table1.val) LowCardinality(UInt64) : 2'. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/Functions/FunctionsConversion.h:1843: 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*) @ 0x000000002b0875aa 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b083246 7. ./src/Core/callOnTypeIndex.h:267: 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&&) @ 0x000000002b00eee5 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01c13e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01afa3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc823 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dcb897 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48558) (comment: 02480_suspicious_lowcard_in_key.sql) (query 5, line 9) (in query: select count() from test where toUInt64(val) = -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:19:30.153670 [ 7056 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: while executing 'FUNCTION toUInt64(val :: 0) -> toUInt64(__table1.val) LowCardinality(UInt64) : 2'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/Functions/FunctionsConversion.h:1843: 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*) @ 0x000000002b0875aa 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b083246 7. ./src/Core/callOnTypeIndex.h:267: 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&&) @ 0x000000002b00eee5 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01c13e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01afa3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc823 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dcb897 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:30.184761 [ 10339 ] {} TCPHandler: Code: 70. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Unexpected inf or nan to integer conversion: while executing 'FUNCTION toUInt64(val :: 0) -> toUInt64(__table1.val) LowCardinality(UInt64) : 2'. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/Functions/FunctionsConversion.h:1843: 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*) @ 0x000000002b0875aa 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b083246 7. ./src/Core/callOnTypeIndex.h:267: 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&&) @ 0x000000002b00eee5 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01c13e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01afa3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc823 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dcb897 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:30.995651 [ 10339 ] {1999ab2e-7247-480c-a291-1e369f9c2247} executeQuery: Code: 36. DB::Exception: Could not decode the provided hash with 'bcrypt_hash'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48640) (comment: 03172_bcrypt_validation.sql) (query 2, line 3) (in query: CREATE USER `03172_user_invalid_bcrypt_hash` IDENTIFIED WITH bcrypt_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Access/AuthenticationData.cpp:250: DB::AuthenticationData::setPasswordHashBinary(std::vector> const&, bool) @ 0x000000002be0509a 6. ./build_docker/./src/Access/AuthenticationData.cpp:530: DB::AuthenticationData::fromAST(DB::ASTAuthenticationData const&, std::shared_ptr, bool) @ 0x000000002be08102 7. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:211: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f977883 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:31.026408 [ 10339 ] {} TCPHandler: Code: 36. DB::Exception: Could not decode the provided hash with 'bcrypt_hash'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Access/AuthenticationData.cpp:250: DB::AuthenticationData::setPasswordHashBinary(std::vector> const&, bool) @ 0x000000002be0509a 6. ./build_docker/./src/Access/AuthenticationData.cpp:530: DB::AuthenticationData::fromAST(DB::ASTAuthenticationData const&, std::shared_ptr, bool) @ 0x000000002be08102 7. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:211: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f977883 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:31.510592 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:19:31.520337 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:19:32.024639 [ 6126 ] {cf036b0e-3a6d-4478-a176-8c619be40bcf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48680) (comment: 02661_read_from_archive_tarbzip2.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/02661_read_from_archive_test_6qnghy8t_tarbz2_archive1.tar.bz2 :: 02661_read_from_archive_test_6qnghy8t_tarbz2_data1.csv') ORDER BY 1, 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:32.052682 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:33.056485 [ 3815 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:33208). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:422: DB::TCPHandler::runImpl() @ 0x00000000316b3019 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:33.065181 [ 3815 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33208, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:33.068596 [ 3815 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33208, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:33.116687 [ 6024 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57190, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:33.122275 [ 6024 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57190, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:35.577883 [ 5971 ] {b6959510-c457-423a-8623-d7978bb08dd2} executeQuery: Code: 57. DB::Exception: Table test_6qnghy8t.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48892) (comment: 02661_read_from_archive_tarbzip2.sh) (query 1, line 1) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_6qnghy8t_tarbz2_archive{1..2}.tar.bz2 :: 02661_read_from_archive_test_6qnghy8t_tarbz2_data1.csv')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:35.616739 [ 5971 ] {} TCPHandler: Code: 57. DB::Exception: Table test_6qnghy8t.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:37.918972 [ 5379 ] {6e97b677-ae18-49a7-b538-ee76f90adace} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 31, line 63) (in query: -- ERRORS -- No arguments SELECT parseReadableSize();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:19:37.926469 [ 5379 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:19:38.028065 [ 5379 ] {c84682fe-7f1d-49dc-93b2-ade532de1b1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize('1 B', '2 B'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 32, line 66) (in query: -- Too many arguments SELECT parseReadableSize('1 B', '2 B');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:19:38.117757 [ 5379 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize('1 B', '2 B'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:19:38.241608 [ 5379 ] {802b3ff9-5db2-41ba-9900-169197d22ba0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: UInt8: In scope SELECT parseReadableSize(12). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 33, line 68) (in query: -- Wrong Type SELECT parseReadableSize(12);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionParseReadable::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fb8366a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:38.247134 [ 5379 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: UInt8: In scope SELECT parseReadableSize(12). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionParseReadable::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fb8366a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:38.431514 [ 5379 ] {e6deb1dc-bf08-46e2-82b4-83675f3695f1} executeQuery: Code: 72. DB::Exception: Invalid expression for function parseReadableSize - Unable to parse readable size numeric component ("oh no"): In scope SELECT parseReadableSize('oh no'). (CANNOT_PARSE_NUMBER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 34, line 70) (in query: -- Invalid input - overall garbage SELECT parseReadableSize('oh no');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x0000000017e431cf 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb83fea 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:38.458738 [ 5379 ] {} TCPHandler: Code: 72. DB::Exception: Invalid expression for function parseReadableSize - Unable to parse readable size numeric component ("oh no"): In scope SELECT parseReadableSize('oh no'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x0000000017e431cf 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb83fea 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:38.632216 [ 5379 ] {ff3357c7-a3ad-490b-b335-5dff749615b0} executeQuery: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("rb"): In scope SELECT parseReadableSize('12.3 rb'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 35, line 72) (in query: -- Invalid input - unknown unit SELECT parseReadableSize('12.3 rb');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb842ab 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:38.644294 [ 5379 ] {} TCPHandler: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("rb"): In scope SELECT parseReadableSize('12.3 rb'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb842ab 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:38.804865 [ 6126 ] {a7a486c1-13fa-4519-bb45-f023cbc43f39} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `ArrLen` in scope SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49174) (comment: 01247_some_msan_crashs_from_22517.sql) (query 2, line 3) (in query: SELECT x FROM (SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 2025.07.13 02:19:38.821193 [ 6126 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `ArrLen` in scope SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 2025.07.13 02:19:38.829147 [ 5379 ] {6a48fda0-d7b1-44e8-b983-d2db2878098c} executeQuery: Code: 27. DB::Exception: Invalid expression for function parseReadableSize - Leading whitespace is not allowed (" 1 B"): In scope SELECT parseReadableSize(' 1 B'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 36, line 74) (in query: -- Invalid input - Leading whitespace SELECT parseReadableSize(' 1 B');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x0000000017e431cf 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb83efe 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:38.863989 [ 5379 ] {} TCPHandler: Code: 27. DB::Exception: Invalid expression for function parseReadableSize - Leading whitespace is not allowed (" 1 B"): In scope SELECT parseReadableSize(' 1 B'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x0000000017e431cf 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb83efe 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.193096 [ 5379 ] {43226d69-b2e1-4f2c-b0c0-26e6105ee169} executeQuery: Code: 632. DB::Exception: Invalid expression for function parseReadableSize - Found trailing characters after readable size string ("1 B leftovers"): In scope SELECT parseReadableSize('1 B leftovers'). (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 37, line 76) (in query: -- Invalid input - Trailing characters SELECT parseReadableSize('1 B leftovers');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x0000000017e431cf 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb843b5 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.201496 [ 5379 ] {} TCPHandler: Code: 632. DB::Exception: Invalid expression for function parseReadableSize - Found trailing characters after readable size string ("1 B leftovers"): In scope SELECT parseReadableSize('1 B leftovers'). (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x0000000017e431cf 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb843b5 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.456734 [ 5379 ] {f6b5cd3c-537a-4e49-9292-35a35d82e165} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Negative sizes are not allowed (-1): In scope SELECT parseReadableSize('-1 KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 38, line 78) (in query: -- Invalid input - Negative sizes are not allowed SELECT parseReadableSize('-1 KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb841bf 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.467686 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Negative sizes are not allowed (-1): In scope SELECT parseReadableSize('-1 KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb841bf 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.627738 [ 5379 ] {1bbd0253-4da7-4d23-9203-94123b013896} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Result is too big for output type ("1.152921504606847e+21"): In scope SELECT parseReadableSize('1000 EiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 39, line 80) (in query: -- Invalid input - Input too large to fit in UInt64 SELECT parseReadableSize('1000 EiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb844c0 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.655299 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Result is too big for output type ("1.152921504606847e+21"): In scope SELECT parseReadableSize('1000 EiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb844c0 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.749743 [ 5379 ] {c61ed5b5-e258-4936-afe4-3121fef53a07} executeQuery: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("xa123"): In scope SELECT parseReadableSize('0xa123 KiB'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 40, line 82) (in query: -- Invalid input - Hexadecimal is not supported SELECT parseReadableSize('0xa123 KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb842ab 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.761127 [ 5379 ] {} TCPHandler: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("xa123"): In scope SELECT parseReadableSize('0xa123 KiB'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb842ab 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.922679 [ 5379 ] {07f279fd-b60e-4a1f-8f47-5e771844f689} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('nan KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 41, line 84) (in query: -- Invalid input - NaN is not supported, with or without sign and with different capitalizations SELECT parseReadableSize('nan KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:39.966555 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('nan KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.062642 [ 5379 ] {421198bb-e16a-4f4f-8016-18d116a3a48c} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('+nan KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 42, line 86) (in query: SELECT parseReadableSize('+nan KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.070937 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('+nan KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.144944 [ 5379 ] {a146e939-2c81-438f-bda4-cf0933433e96} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -nan: In scope SELECT parseReadableSize('-nan KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 43, line 87) (in query: SELECT parseReadableSize('-nan KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.147748 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -nan: In scope SELECT parseReadableSize('-nan KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.218603 [ 5379 ] {c858e102-d887-4837-aa84-d9d98d1eb6ea} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('NaN KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 44, line 88) (in query: SELECT parseReadableSize('NaN KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.224603 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('NaN KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.299603 [ 5379 ] {0f0b207b-23d6-4aeb-b1af-11a11e5d8642} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('inf KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 45, line 89) (in query: -- Invalid input - Infinite is not supported, with or without sign, in all its forms SELECT parseReadableSize('inf KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.304384 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('inf KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.484906 [ 5379 ] {aeeb39c9-7ce1-4cc0-a1f4-fcc1ec62fdef} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+inf KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 46, line 91) (in query: SELECT parseReadableSize('+inf KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.489480 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+inf KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.543753 [ 5379 ] {7b46ced6-8c8d-4488-810b-49f00a0d8ed3} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-inf KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 47, line 92) (in query: SELECT parseReadableSize('-inf KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.548157 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-inf KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.652660 [ 5379 ] {def5bbb7-831e-4ba6-aa53-6f913aa0b724} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('infinite KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 48, line 93) (in query: SELECT parseReadableSize('infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.662440 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('infinite KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.749663 [ 5379 ] {ce90a8cf-ef5b-4114-bdd1-ef557be573dd} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+infinite KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 49, line 94) (in query: SELECT parseReadableSize('+infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.758663 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+infinite KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.797288 [ 5379 ] {d9e99f14-90aa-4ffe-a294-104996f8f29b} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-infinite KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 50, line 95) (in query: SELECT parseReadableSize('-infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.801196 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-infinite KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.837800 [ 5379 ] {72dda031-751a-40a5-b388-6aa4046c55f2} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Inf KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 51, line 96) (in query: SELECT parseReadableSize('Inf KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:40.857377 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Inf KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:41.021544 [ 5379 ] {a8a1b5b0-9dfd-4924-b5a8-a649ec4f31c3} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Infinite KiB'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48724) (comment: 03165_parseReadableSize.sql) (query 52, line 97) (in query: SELECT parseReadableSize('Infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:41.028327 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Infinite KiB'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000001fb84b4f 5. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000001fb840cb 6. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fb831dd 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:41.328374 [ 4477 ] {e099104f-8ac4-4e56-9154-d35a1beddbe0} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 1.3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60012) (comment: 02008_tuple_to_name_value_pairs.sql) (query 12, line 22) (in query: SELECT tupleToNameValuePairs(tuple(1, 1.3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11a0c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.333386 [ 4477 ] {} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 1.3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11a0c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.420695 [ 4477 ] {eccf0c0c-4b77-4d55-8d31-a2e9099011e4} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, [1, 2])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60012) (comment: 02008_tuple_to_name_value_pairs.sql) (query 13, line 23) (in query: SELECT tupleToNameValuePairs(tuple(1, [1,2]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11a0c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.445837 [ 4477 ] {} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, [1, 2])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11a0c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.681278 [ 4477 ] {84ad8718-136f-4f09-97a5-bdae38a17d8b} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 'a')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60012) (comment: 02008_tuple_to_name_value_pairs.sql) (query 14, line 24) (in query: SELECT tupleToNameValuePairs(tuple(1, 'a'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11a0c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.684192 [ 4477 ] {} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 'a')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11a0c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.950709 [ 4477 ] {866cf15f-79bc-4c24-9340-0ba9733e7185} executeQuery: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(33). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60012) (comment: 02008_tuple_to_name_value_pairs.sql) (query 15, line 25) (in query: SELECT tupleToNameValuePairs(33);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11b1a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:41.955126 [ 4477 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(33). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d11b1a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:42.693525 [ 4529 ] {7ff42dc3-84d1-4618-90a6-312cff38fe95} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 2, line 37) (in query: -- -- error cases -- -- INTERSECT WITH RECURSIVE x AS (SELECT 1 AS n INTERSECT SELECT n+1 FROM x) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:42.707353 [ 4529 ] {} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:42.857571 [ 4529 ] {40e67f55-a40d-45ef-8521-41db0bea665a} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 3, line 45) (in query: WITH RECURSIVE x AS (SELECT 1 AS n INTERSECT ALL SELECT n+1 FROM x) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:42.867378 [ 4529 ] {} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.039212 [ 4529 ] {5d50772e-9b21-4422-ba02-69149a3024bf} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 4, line 48) (in query: -- EXCEPT WITH RECURSIVE x AS (SELECT 1 AS n EXCEPT SELECT n+1 FROM x) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.069737 [ 4529 ] {} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.186486 [ 4529 ] {e5cd4d5c-ce15-4493-9453-767729680273} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 5, line 52) (in query: WITH RECURSIVE x AS (SELECT 1 AS n EXCEPT ALL SELECT n+1 FROM x) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.200703 [ 4529 ] {} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002851958f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5873: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0aa1f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.320021 [ 4694 ] {03f76885-f92f-4780-aee9-db49efb957c6} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 10, line 13) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select first_valueState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.323136 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.427022 [ 4529 ] {75373755-9657-4e73-852e-09efc928a040} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope x AS (SELECT n FROM x). (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 6, line 55) (in query: -- no non-recursive term WITH RECURSIVE x AS (SELECT n FROM x) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.435683 [ 4529 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope x AS (SELECT n FROM x). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.509271 [ 4694 ] {6aa7a331-d0be-47f1-bbf0-e2cbe29c1bea} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(anyLast_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: anyLast_respect_nulls instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 11, line 14) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select last_value_respect_nullsState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.513332 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(anyLast_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: anyLast_respect_nulls instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.671749 [ 4694 ] {8a298852-8eb6-424c-b74a-d6158e27929a} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of anyLast_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 12, line 15) (in query: SELECT last_value_respect_nullsMerge(t) FROM (Select first_value_respect_nullsState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.685683 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of anyLast_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.733067 [ 7056 ] {edc9096a-980a-4768-a6f6-939c27ef2c6f} executeQuery: Code: 57. DB::Exception: Table test_6qnghy8t.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60294) (comment: 02661_read_from_archive_tarbzip2.sh) (query 1, line 1) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_6qnghy8t_tarbz2_archive*.tar.bz2 :: *.csv')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.764696 [ 7056 ] {} TCPHandler: Code: 57. DB::Exception: Table test_6qnghy8t.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.786726 [ 4529 ] {66eaaf4a-ddcd-4889-9e37-a121506498bd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope SELECT n FROM x. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 7, line 59) (in query: -- recursive term in the left hand side (strictly speaking, should allow this) WITH RECURSIVE x AS (SELECT n FROM x UNION ALL SELECT 1 AS n) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5819: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc09924 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.820964 [ 4529 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope SELECT n FROM x. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5819: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc09924 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10601 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.891745 [ 4694 ] {d465c91c-de53-4dfd-9c89-d1e2f22d3ef8} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 13, line 16) (in query: SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:43.906710 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028420157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:44.168034 [ 4694 ] {d2557e24-27a2-4663-9e72-992523d9a306} executeQuery: Code: 117. DB::Exception: Incorrect type (0) in any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 14, line 18) (in query: -- Invalid (starts at 1) SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8), std::basic_string, std::basic_string::allocator>>(int, FormatStringHelperImpl::type, std::basic_string::type_identity, std::basic_string::allocator>>::type>, std::basic_string::type_identity<_BitInt(8)>&&, std::basic_string::type_identity, std::basic_string::allocator>>&&) @ 0x00000000263665cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:171: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002635c304 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:44.181411 [ 4694 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect type (0) in any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8), std::basic_string, std::basic_string::allocator>>(int, FormatStringHelperImpl::type, std::basic_string::type_identity, std::basic_string::allocator>>::type>, std::basic_string::type_identity<_BitInt(8)>&&, std::basic_string::type_identity, std::basic_string::allocator>>&&) @ 0x00000000263665cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:171: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002635c304 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:44.973813 [ 4694 ] {1b06bbdc-9565-48d3-90fb-321b25a1a166} executeQuery: Code: 117. DB::Exception: Incorrect type (NULL) in non-nullable any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 17, line 23) (in query: -- Set to NULL SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:163: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002635ba60 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:44.992139 [ 4694 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect type (NULL) in non-nullable any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:163: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002635ba60 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:19:45.331859 [ 4529 ] {230aa708-2c77-4c0b-b061-197618712981} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n + 1 FROM y LEFT JOIN x ON x.n = y.a WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 11, line 67) (in query: -- LEFT JOIN WITH RECURSIVE x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n+1 FROM y LEFT JOIN x ON x.n = y.a WHERE n < 10) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:45.376679 [ 5480 ] {9b4fd92f-177d-474c-be7e-7a54a5e2a156} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 18, line 20) (in query: select makeDate(cast(1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.391049 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.396433 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n + 1 FROM y LEFT JOIN x ON x.n = y.a WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:45.518336 [ 6914 ] {} test_97fzo5n0.xxxx_yyy (e91b7945-88f0-4b48-ad37-9f96f618d84a): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:19:45.548415 [ 5480 ] {85d09b55-ec85-4d11-98c3-966b7adc6af4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 19, line 21) (in query: select makeDate(cast(-1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.564284 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.578597 [ 6914 ] {} DatabaseCatalog: Cannot drop table test_97fzo5n0.xxxx_yyy (e91b7945-88f0-4b48-ad37-9f96f618d84a). 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbae13 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:45.726563 [ 5480 ] {96193ac1-3c1f-4dd8-9fdb-ac8d0dc46ed2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 20, line 22) (in query: select makeDate(cast(1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.748006 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.800145 [ 4694 ] {de395a11-f38e-4fa5-bb86-e87d51e66b31} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 8.: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49168) (comment: 02922_respect_nulls_states.sql) (query 20, line 28) (in query: -- Set to other value, but without providing value SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/IO/ReadHelpers.h:117: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c606858 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:168: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002635c16b 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:19:45.824169 [ 4694 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 8.: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/IO/ReadHelpers.h:117: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c606858 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:168: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002635c16b 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:19:45.861452 [ 5480 ] {b2589192-b387-4716-a21a-d3e072cca963} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 21, line 23) (in query: select makeDate(cast(-1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:45.892405 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.026968 [ 5480 ] {0439c5aa-c67d-4bab-848a-2b208ba10a67} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 22, line 24) (in query: select makeDate(cast(1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.038232 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.182006 [ 5480 ] {0a102400-56d3-414e-957c-489349cefb9a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 23, line 25) (in query: select makeDate(cast(-1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.187519 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.285483 [ 5480 ] {ce3b8a44-fd56-4b85-a61b-297f53f1c2fb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 24, line 26) (in query: select makeDate(cast(1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.324698 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.377282 [ 4529 ] {aa6d1770-174c-4640-9856-0bc55f3026c6} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n + 1 FROM x RIGHT JOIN y ON x.n = y.a WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 12, line 74) (in query: -- RIGHT JOIN WITH RECURSIVE x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n+1 FROM x RIGHT JOIN y ON x.n = y.a WHERE n < 10) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:46.385049 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n + 1 FROM x RIGHT JOIN y ON x.n = y.a WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:46.443102 [ 5480 ] {b63a2df3-b44b-4092-b88c-1c26d6fd2c37} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 25, line 27) (in query: select makeDate(cast(-1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.457337 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:46.603891 [ 2824 ] {a57c3a67-9000-4b2a-8c3f-5dc13dfbaac7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34128) (comment: 02372_analyzer_join.gen.sql) (in query: DROP DATABASE IF EXISTS test_0uzhs0fi SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:46.605624 [ 2824 ] {a57c3a67-9000-4b2a-8c3f-5dc13dfbaac7} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:47.137899 [ 4529 ] {c9198ead-f5e1-43be-ace4-d9244674dcd0} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n + 1 FROM x FULL OUTER JOIN y ON x.n = y.a WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 13, line 80) (in query: -- FULL JOIN WITH RECURSIVE x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n+1 FROM x FULL JOIN y ON x.n = y.a WHERE n < 10) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:47.143941 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n + 1 FROM x FULL OUTER JOIN y ON x.n = y.a WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:47.610665 [ 4529 ] {504866dd-5813-45f5-af32-36c8336a21cb} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT n + 1 FROM x WHERE n IN (SELECT * FROM x)). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 14, line 86) (in query: -- subquery WITH RECURSIVE x AS (SELECT 1 AS n UNION ALL SELECT n+1 FROM x WHERE n IN (SELECT * FROM x)) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:47.615766 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT n + 1 FROM x WHERE n IN (SELECT * FROM x)). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.106895 [ 4529 ] {a3bb8248-070e-44df-9147-cf154b8e9656} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT count(*) FROM x). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 15, line 91) (in query: -- aggregate functions WITH RECURSIVE x AS (SELECT 1 AS n UNION ALL SELECT count(*) FROM x) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.114334 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT count(*) FROM x). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.129292 [ 6951 ] {61cebb97-666f-419c-988a-eeebb763c831} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01493_alter_remove_wrong_default.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_g12s6nm1.default_table (MODIFY COLUMN `key` REMOVE MATERIALIZED)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.177645 [ 6951 ] {61cebb97-666f-419c-988a-eeebb763c831} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60432) (comment: 01493_alter_remove_wrong_default.sql) (query 3, line 11) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.243144 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.392027 [ 6024 ] {ca7929ef-b930-43bc-9448-cec81ae2f8cf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=2): While executing MergingAggregatedTransform. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60086) (comment: 02521_grouping_sets_plus_memory_efficient_aggr.sql) (query 2, line 3) (in query: select number as a, number+1 as b from remote('127.0.0.{1,2}', numbers_mt(1e5)) group by grouping sets ((a), (b)) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Interpreters/Aggregator.cpp:3135: DB::Aggregator::mergeBlocks(std::map>, std::less, std::allocator>>>>, DB::AggregatedDataVariants&, unsigned long, std::atomic&) @ 0x000000002d6d6f00 8. ./build_docker/./src/Processors/Transforms/MergingAggregatedTransform.cpp:264: DB::MergingAggregatedTransform::generate() @ 0x000000003216077d 9. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:96: DB::IAccumulatingTransform::work() @ 0x00000000317ff48d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.468690 [ 6024 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=2): While executing MergingAggregatedTransform. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Interpreters/Aggregator.cpp:3135: DB::Aggregator::mergeBlocks(std::map>, std::less, std::allocator>>>>, DB::AggregatedDataVariants&, unsigned long, std::atomic&) @ 0x000000002d6d6f00 8. ./build_docker/./src/Processors/Transforms/MergingAggregatedTransform.cpp:264: DB::MergingAggregatedTransform::generate() @ 0x000000003216077d 9. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:96: DB::IAccumulatingTransform::work() @ 0x00000000317ff48d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.579388 [ 4529 ] {7d6bd9bf-509b-4555-aa03-45f3f6b47254} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT sum(n) FROM x). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 16, line 95) (in query: WITH RECURSIVE x AS (SELECT 1 AS n UNION ALL SELECT sum(n) FROM x) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.598280 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT sum(n) FROM x). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.607130 [ 6951 ] {c31f3a49-1beb-4116-aa6f-4bcb93fb4947} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01493_alter_remove_wrong_default.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_g12s6nm1.default_table (MODIFY COLUMN `key` REMOVE ALIAS)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.658954 [ 6951 ] {c31f3a49-1beb-4116-aa6f-4bcb93fb4947} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60432) (comment: 01493_alter_remove_wrong_default.sql) (query 4, line 12) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:48.671504 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.030010 [ 4529 ] {e1d47d52-0c87-443f-81e5-075274531276} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT n + 1 FROM x ORDER BY 1 ASC). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 17, line 98) (in query: -- ORDER BY WITH RECURSIVE x AS (SELECT 1 AS n UNION ALL SELECT n+1 FROM x ORDER BY 1) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.068117 [ 6951 ] {435c4c7b-dfe3-4f7e-b4a0-fc2e960bd07d} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01493_alter_remove_wrong_default.sql) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_g12s6nm1.default_table (MODIFY COLUMN `value1` REMOVE DEFAULT)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.116010 [ 6951 ] {435c4c7b-dfe3-4f7e-b4a0-fc2e960bd07d} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60432) (comment: 01493_alter_remove_wrong_default.sql) (query 5, line 14) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.133757 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS n UNION ALL SELECT n + 1 FROM x ORDER BY 1 ASC). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.141958 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.563733 [ 6951 ] {e8e0f678-ba04-4c02-adfa-2c83299973b6} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01493_alter_remove_wrong_default.sql) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE test_g12s6nm1.default_table (MODIFY COLUMN `value1` REMOVE ALIAS)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.580026 [ 6951 ] {e8e0f678-ba04-4c02-adfa-2c83299973b6} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60432) (comment: 01493_alter_remove_wrong_default.sql) (query 6, line 15) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.583901 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.943780 [ 6951 ] {9799f3a1-254f-4ba7-8ebf-0cd1b01b91e8} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01493_alter_remove_wrong_default.sql) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE test_g12s6nm1.default_table (MODIFY COLUMN `value2` REMOVE DEFAULT)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.975716 [ 6951 ] {9799f3a1-254f-4ba7-8ebf-0cd1b01b91e8} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60432) (comment: 01493_alter_remove_wrong_default.sql) (query 7, line 17) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.981901 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:49.995327 [ 4529 ] {71541800-0a21-40bf-b29e-a7e915469c13} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS id UNION ALL SELECT id + 1 FROM y WHERE id < 5). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60216) (comment: 03040_recursive_cte_postgres_6.sql) (query 18, line 102) (in query: -- FIXME: indeterministic results -- -- target list has a recursive query name -- WITH RECURSIVE x AS (SELECT 1 AS id -- UNION ALL -- SELECT (SELECT * FROM x) FROM x WHERE id < 5 -- ) SELECT * FROM x; -- { serverError UNKNOWN_TABLE, CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN } -- mutual recursive query (not implemented) WITH RECURSIVE x AS (SELECT 1 AS id UNION ALL SELECT id+1 FROM y WHERE id < 5), y AS (SELECT 1 AS id UNION ALL SELECT id+1 FROM x WHERE id < 5) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:19:50.002066 [ 4529 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of x AS (SELECT 1 AS id UNION ALL SELECT id + 1 FROM y WHERE id < 5). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000322399aa 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223522e 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:19:50.238796 [ 6951 ] {ef805572-f473-4d1a-93e2-11544cb2ecd3} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01493_alter_remove_wrong_default.sql) (in query: /* ddl_entry=query-0000000008 */ ALTER TABLE test_g12s6nm1.default_table (MODIFY COLUMN `value2` REMOVE MATERIALIZED)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:50.281086 [ 6951 ] {ef805572-f473-4d1a-93e2-11544cb2ecd3} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60432) (comment: 01493_alter_remove_wrong_default.sql) (query 8, line 18) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:50.297115 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:19:51.726304 [ 3792 ] {20da3773-8cc0-49d0-9693-b2412930da36} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48942) (comment: 01099_parallel_distributed_insert_select.sql) (in query: DROP DATABASE IF EXISTS test_qloe55mq SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:19:51.728166 [ 3792 ] {20da3773-8cc0-49d0-9693-b2412930da36} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:51.940934 [ 5480 ] {07865199-c5e1-4cfa-b78a-a0a8cdc456af} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 58, line 63) (in query: select makeDate('1980', '10', '20');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.040923 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.172897 [ 5480 ] {66e5b061-0bca-446b-b2ae-ecf62c316d7b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 59, line 64) (in query: select makeDate('-1980', 3, 17);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.192224 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.351301 [ 5480 ] {ae140e4e-6c1c-4847-bd98-8f18b285889c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 60, line 66) (in query: select makeDate('aa', 3, 24);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.369843 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.413215 [ 5480 ] {e1517947-a12d-4dfc-a01a-866a6f611b33} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 61, line 67) (in query: select makeDate(1994, 'aa', 24);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.427534 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.529346 [ 5480 ] {a2d69741-719c-4936-8e43-9e26199519c2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 62, line 68) (in query: select makeDate(1984, 3, 'aa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.536102 [ 5480 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:52.823439 [ 6024 ] {c85c416b-4495-4173-8535-e02741aa1d7b} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_7.a INNER JOIN (SELECT b AS j, b AS bb FROM test_7.b) USING (j). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57180) (comment: 03107_ill_formed_select_in_materialized_view.sql) (query 7, line 12) (in query: CREATE MATERIALIZED VIEW view_4 ( bb UInt64, cnt UInt64) Engine=MergeTree ORDER BY bb POPULATE AS SELECT bb, count() AS cnt FROM (SELECT a, b AS j, b AS bb FROM a INNER JOIN (SELECT b AS j, b AS bb FROM b ) USING (j)) GROUP BY bb;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcebe46 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x000000002dc8f13a 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e1be 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:52.828777 [ 6024 ] {} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_7.a INNER JOIN (SELECT b AS j, b AS bb FROM test_7.b) USING (j). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcebe46 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x000000002dc8f13a 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e1be 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:52.952084 [ 6126 ] {ffff088b-affd-4d72-a9a1-50bd8e41cb88} executeQuery: Code: 703. DB::Exception: Expected dictGet function first argument identifier to contain 1 or 2 parts. Actual 't.nest.a'. In scope SELECT dictGet(t.nest.a, concat(currentDatabase(), '.dict.dict'), 's', number) FROM numbers(5). (INVALID_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57242) (comment: 01936_three_parts_identifiers_in_wrong_places.sql) (query 2, line 3) (in query: SELECT dictGet(t.nest.a, concat(currentDatabase(), '.dict.dict'), 's', number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x0000000023ab024f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f95 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:53.011899 [ 6126 ] {} TCPHandler: Code: 703. DB::Exception: Expected dictGet function first argument identifier to contain 1 or 2 parts. Actual 't.nest.a'. In scope SELECT dictGet(t.nest.a, concat(currentDatabase(), '.dict.dict'), 's', number) FROM numbers(5). (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x0000000023ab024f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f95 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:53.130847 [ 6126 ] {fe03ebfd-49e9-4a00-b341-52769c29d651} executeQuery: Code: 703. DB::Exception: Expected dictGetFloat64 function first argument identifier to contain 1 or 2 parts. Actual 't.b.s'. In scope SELECT dictGetFloat64(t.b.s, 'database_for_dict.dict1', dictGetFloat64('Ta\0', toUInt64('databas\0_for_dict.dict1databas\0_for_dict.dict1', dictGetFloat64('', '', toUInt64(1048577), toDate(NULL)), NULL), toDate(dictGetFloat64(257, 'database_for_dict.dict1database_for_dict.dict1', '', toUInt64(NULL), 2, toDate(NULL)), '2019-05-2\0')), NULL, toUInt64(dictGetFloat64('', '', toUInt64(-9223372036854775808), toDate(NULL)), NULL)). (INVALID_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57242) (comment: 01936_three_parts_identifiers_in_wrong_places.sql) (query 3, line 5) (in query: SELECT dictGetFloat64(t.b.s, 'database_for_dict.dict1', dictGetFloat64('Ta\0', toUInt64('databas\0_for_dict.dict1databas\0_for_dict.dict1', dictGetFloat64('', '', toUInt64(1048577), toDate(NULL)), NULL), toDate(dictGetFloat64(257, 'database_for_dict.dict1database_for_dict.dict1', '', toUInt64(NULL), 2, toDate(NULL)), '2019-05-2\0')), NULL, toUInt64(dictGetFloat64('', '', toUInt64(-9223372036854775808), toDate(NULL)), NULL));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x0000000023ab024f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f95 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:53.153049 [ 6126 ] {} TCPHandler: Code: 703. DB::Exception: Expected dictGetFloat64 function first argument identifier to contain 1 or 2 parts. Actual 't.b.s'. In scope SELECT dictGetFloat64(t.b.s, 'database_for_dict.dict1', dictGetFloat64('Ta\0', toUInt64('databas\0_for_dict.dict1databas\0_for_dict.dict1', dictGetFloat64('', '', toUInt64(1048577), toDate(NULL)), NULL), toDate(dictGetFloat64(257, 'database_for_dict.dict1database_for_dict.dict1', '', toUInt64(NULL), 2, toDate(NULL)), '2019-05-2\0')), NULL, toUInt64(dictGetFloat64('', '', toUInt64(-9223372036854775808), toDate(NULL)), NULL)). (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x0000000023ab024f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f95 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:53.426035 [ 6126 ] {3e20e51a-1596-4475-8ad3-85a3419548ef} executeQuery: Code: 703. DB::Exception: Expected identifier 'test_01103.t1_distr.id' to contain 1 or 2 parts to be resolved as table expression. In scope system.one. (INVALID_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57242) (comment: 01936_three_parts_identifiers_in_wrong_places.sql) (query 4, line 7) (in query: SELECT NULL AND (2147483648 AND NULL) AND -2147483647, toUUID(((1048576 AND NULL) AND (2147483647 AND 257 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id), '00000000-e1fe-11e\0-bb8f\0853d60c00749'), stringToH3('89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:662: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d146b24 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14860a 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3707: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10fc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:53.440487 [ 6126 ] {} TCPHandler: Code: 703. DB::Exception: Expected identifier 'test_01103.t1_distr.id' to contain 1 or 2 parts to be resolved as table expression. In scope system.one. (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:662: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d146b24 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14860a 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3707: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10fc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:19:54.374304 [ 5480 ] {aa5c2cee-48d8-4eab-9b79-95069e60b823} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 72, line 81) (in query: select makeDate(1980);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:54.385034 [ 5480 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:54.497599 [ 5480 ] {f77307d1-68a2-4b7d-849f-afab1e56143d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60178) (comment: 02242_make_date.sql) (query 73, line 82) (in query: select makeDate(1980, 1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:54.514019 [ 5480 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:19:56.503263 [ 3815 ] {ae8a8b08-ccc2-4972-8797-436064d75157} executeQuery: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36528) (comment: 03319_http_exception_formatting_during_interpretation.sh) (in query: SELECT * FROM nonexistent.nonexistent FORMAT JSONLines), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa05e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4b65df 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d13fbf3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29c14 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc581e1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 21. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 22. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 23. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:19:56.507255 [ 3815 ] {ae8a8b08-ccc2-4972-8797-436064d75157} DynamicQueryHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa05e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4b65df 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d13fbf3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29c14 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc581e1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 21. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 22. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 23. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:57.921434 [ 6126 ] {46a9910f-e8a2-422e-8851-09cf5f2884f8} executeQuery: Code: 43. DB::Exception: Function untuple can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57438) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3204: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc41f75 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:57.932676 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3204: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc41f75 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:19:59.001747 [ 6024 ] {bffd87e4-ab07-4f66-a126-3ef00c034661} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57450) (comment: 02885_arg_min_max_combinator.sql) (query 4, line 4) (in query: select sumArgMin() from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:194: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x00000000282801d9 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8468 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:59.043855 [ 6024 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:194: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x00000000282801d9 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8468 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:59.291962 [ 6024 ] {a2a0330b-550b-4eca-8ac9-588c9cd054c9} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57450) (comment: 02885_arg_min_max_combinator.sql) (query 5, line 5) (in query: select sumArgMin(number) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./src/AggregateFunctions/FactoryHelpers.h:26: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000268f8744 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:59.330865 [ 6024 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./src/AggregateFunctions/FactoryHelpers.h:26: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000268f8744 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:19:59.624051 [ 6024 ] {c8ca7432-da5a-47ea-aab6-8cc10aa12140} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57450) (comment: 02885_arg_min_max_combinator.sql) (query 6, line 6) (in query: -- Try passing a non comparable type, for example an AggregationState select sumArgMin(number, unhex('0000000000000000')::AggregateFunction(sum, UInt64)) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:61: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028280f25 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:59.640854 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:61: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028280f25 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:19:59.749923 [ 5971 ] {bdfe558a-a074-4e32-b4a3-64727e7b2d25} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36332) (comment: 01070_exception_code_in_query_log_table.sql) (query 2, line 2) (in query: SELECT * FROM test_table_for_01070_exception_code_in_query_log_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:19:59.759312 [ 5971 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:00.541786 [ 3885 ] {17bf87be-e520-4d8d-bbc1-15b76ce987c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47716) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (query 4, line 10) (in query: SELECT length(groupUniqArray(v)) FROM group_uniq_arr_int GROUP BY id ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:00.568007 [ 3885 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.252238 [ 3815 ] {7f892a9f-d7b3-48f6-bcbb-ab8b87014895} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36544) (comment: 00692_if_exception_code.sql) (query 2, line 3) (in query: SELECT if();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.274378 [ 3815 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.392876 [ 4477 ] {46909bbf-7ca4-49c4-8fa3-34bb37751d60} executeQuery: Code: 57. DB::Exception: Table test_5.data already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02904_distributed_settings_background_insert_compatibility.gen.sql) (in query: /* ddl_entry=query-0000000058 */ CREATE TABLE test_5.data UUID '2f5cfd6a-e60a-432e-a204-fecfce28c8b8' (`key` Int32) ENGINE = Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.416146 [ 4477 ] {46909bbf-7ca4-49c4-8fa3-34bb37751d60} executeQuery: Code: 57. DB::Exception: Table test_5.data already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57392) (comment: 02904_distributed_settings_background_insert_compatibility.gen.sql) (query 33, line 43) (in query: create table data (key Int) engine=Null();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.427422 [ 3815 ] {c6b31746-b4fd-49db-b703-f43a00414860} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36544) (comment: 00692_if_exception_code.sql) (query 3, line 4) (in query: SELECT if(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.437168 [ 3815 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.451862 [ 4477 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.data already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.516641 [ 3815 ] {f7f20ef5-d838-4841-ab86-5efe578c2e04} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36544) (comment: 00692_if_exception_code.sql) (query 4, line 5) (in query: SELECT if(1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:03.523560 [ 3815 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:04.516886 [ 2824 ] {d3fbd7cb-1256-4e3c-a36b-d8fecc22508b} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 8.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36674) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:04.549048 [ 2824 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 8.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:05.297043 [ 4468 ] {b5be53d4-eff7-4650-b59d-7affd33e2e4c} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 16.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36742) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:05.330491 [ 4468 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 16.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:06.068447 [ 3900 ] {c7d732d1-f7f4-4d0c-b08b-d27f379fcaf9} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 32.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36798) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:06.073272 [ 3900 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 32.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:06.767159 [ 7056 ] {7934a028-748b-44d0-985f-c04d1d2024ee} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 64.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36856) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:06.771848 [ 7056 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 64.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:07.632406 [ 3815 ] {347611bf-8b6f-4c29-9c7d-1dd1cacce4ae} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 128.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36954) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:07.663675 [ 3815 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 128.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:08.103396 [ 6249 ] {28f8cb60-deb1-45ac-8a43-f78a96114645} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=845). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38674) (comment: 03165_storage_merge_view_prewhere.sql) (query 10, line 16) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`whatever` AS `whatever` FROM `test_15`.`ids` AS `__table1` ALL INNER JOIN merge(_CAST('test_15', 'String'), 'data*') AS `__table2` ON `__table1`.`id` = `__table2`.`id` WHERE `__table2`.`status` IN ['CREATED', 'CREATING'] ORDER BY `__table2`.`event_time` DESC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.136335 [ 6249 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=845). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.160084 [ 5971 ] {f8813a21-f1be-4829-b755-a34129e9cb9f} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=845). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36774) (comment: 03165_storage_merge_view_prewhere.sql) (query 10, line 16) (in query: SELECT id, whatever FROM ids AS l INNER JOIN merge(currentDatabase(), 'data*') AS s ON l.id = s.id WHERE (status IN ['CREATED', 'CREATING']) ORDER BY event_time DESC ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:20:08.172253 [ 5971 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=845). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.242858 [ 3863 ] {f4693f5d-0e1f-4a8d-bd77-97a267b19189} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53230) (comment: 03165_storage_merge_view_prewhere.sql) (query 10, line 16) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`whatever` AS `whatever` FROM `test_15`.`ids` AS `__table1` ALL INNER JOIN merge(_CAST('test_15', 'String'), 'data*') AS `__table2` ON `__table1`.`id` = `__table2`.`id` WHERE `__table2`.`status` IN ['CREATED', 'CREATING'] ORDER BY `__table2`.`event_time` DESC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f9d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.278998 [ 3863 ] {f4693f5d-0e1f-4a8d-bd77-97a267b19189} 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.9]:9000 -> [::ffff:127.0.0.1]:53230). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:08.295080 [ 3863 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f9d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.323130 [ 3816 ] {5b2544ba-527a-40bf-973f-af79ff8d0608} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:50576). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50576) (comment: 03165_storage_merge_view_prewhere.sql) (query 10, line 16) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`whatever` AS `whatever` FROM `test_15`.`ids` AS `__table1` ALL INNER JOIN merge(_CAST('test_15', 'String'), 'data*') AS `__table2` ON `__table1`.`id` = `__table2`.`id` WHERE `__table2`.`status` IN ['CREATED', 'CREATING'] ORDER BY `__table2`.`event_time` DESC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x00000000316ad6e3 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.327139 [ 3816 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:50576). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x00000000316ad6e3 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:20:08.452157 [ 2824 ] {b8162b61-5f69-49d8-9ac5-0718a47df79f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 256.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37024) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:08.483549 [ 2824 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 256.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:09.294989 [ 5480 ] {d23141df-1292-4bf5-9726-5082cd53d4ec} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 512.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52770) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:09.320190 [ 5480 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 512.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:10.096253 [ 4477 ] {a8cc326d-9f6d-49b7-a4bb-7be57858728f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 1.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52834) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:10.122856 [ 4477 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 1.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:10.958906 [ 4529 ] {365e6674-fba7-4852-9b31-eb5de472b78d} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.29 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 2.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52926) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:11.172016 [ 4529 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.29 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 2.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:12.057098 [ 5971 ] {5b7ee8b7-65eb-41e6-addf-55cf0b449a3f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.52 MiB (attempt to allocate chunk of 1.11 MiB bytes), maximum: 4.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53026) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:12.061474 [ 5971 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.52 MiB (attempt to allocate chunk of 1.11 MiB bytes), maximum: 4.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:13.021099 [ 6024 ] {30ec88bf-e42a-4b60-bdce-7739b2e032d0} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 16.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 8.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53118) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:13.084780 [ 6024 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 16.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 8.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:14.149737 [ 10341 ] {43ec8f7a-092d-463b-8497-d2b616882b6f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 16.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 16.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53206) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:14.152998 [ 10341 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 16.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 16.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:14.934179 [ 3900 ] {837c8120-bac8-4c0c-a8a5-55e5da093286} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53040) (comment: 01780_dict_get_or_null.sql) (query 10, line 34) (in query: DROP DICTIONARY simple_key_dictionary;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:14.945276 [ 3900 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.106596 [ 10341 ] {831dab83-dd07-4671-b0a6-66a51c43011b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44058) (comment: 01780_dict_get_or_null.sql) (in query: DROP DATABASE IF EXISTS test_069xrfrc SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.109711 [ 10341 ] {831dab83-dd07-4671-b0a6-66a51c43011b} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:15.121411 [ 3863 ] {18459778-bcb7-4cfd-9bc2-b1635db5838e} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 32.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 32.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53288) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageLog.cpp:365: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x00000000308735fd 17. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::pair::pair[abi:ne190107] const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&, 0ul, 0ul, 1ul, 2ul, 3ul, 4ul>(std::piecewise_construct_t, std::tuple&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&, std::__tuple_indices<0ul>, std::__tuple_indices<0ul, 1ul, 2ul, 3ul, 4ul>) @ 0x0000000030873414 18. ./contrib/llvm-project/libcxx/include/__utility/pair.h:254: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000003087328b 19. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>, bool> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__emplace_unique_key_args, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(String const&, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000030872f5d 20. ./contrib/llvm-project/libcxx/include/map:1224: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003086b2dd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x000000003085b07a 24. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x000000003085ace2 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 2025.07.13 02:20:15.122837 [ 3863 ] {18459778-bcb7-4cfd-9bc2-b1635db5838e} FileChecker: Will truncate file store/731/731cdbad-591f-4bc4-a16f-90c1a7ce2f42/x.bin that has size 3145728 to size 0 2025.07.13 02:20:15.124471 [ 3863 ] {18459778-bcb7-4cfd-9bc2-b1635db5838e} FileChecker: Will truncate file store/731/731cdbad-591f-4bc4-a16f-90c1a7ce2f42/y.bin that has size 3145728 to size 0 2025.07.13 02:20:15.149789 [ 3863 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 32.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 32.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageLog.cpp:365: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x00000000308735fd 17. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::pair::pair[abi:ne190107] const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&, 0ul, 0ul, 1ul, 2ul, 3ul, 4ul>(std::piecewise_construct_t, std::tuple&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&, std::__tuple_indices<0ul>, std::__tuple_indices<0ul, 1ul, 2ul, 3ul, 4ul>) @ 0x0000000030873414 18. ./contrib/llvm-project/libcxx/include/__utility/pair.h:254: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000003087328b 19. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>, bool> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__emplace_unique_key_args, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(String const&, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000030872f5d 20. ./contrib/llvm-project/libcxx/include/map:1224: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003086b2dd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x000000003085b07a 24. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x000000003085ace2 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.155181 [ 6899 ] {8737d4cd-e469-4998-a877-43277da55e54} BackupsWorker: Failed to make backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_3_inc_2_bad.zip'): Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ZipArchiveReader::showError(String const&) const @ 0x000000002b5f9baa 5. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:186: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x000000002b5fce8f 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:347: DB::ZipArchiveReader::ReadBufferFromZipArchive::showError(String const&) const @ 0x000000002b5fda2d 7. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:243: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd7f6 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 9. ./build_docker/./src/Backups/BackupImpl.cpp:424: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf7bdc8 10. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf77095 11. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf75f27 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072c39 13. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c0719c6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 15. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf7f95a 16. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf7f673 17. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf4b80a 18. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4a221 19. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5ecfe 20. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56be3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 22. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf479f3 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476eb 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:15.156247 [ 6899 ] {8737d4cd-e469-4998-a877-43277da55e54} BackupImpl: An error happened, the backup won't be completed 2025.07.13 02:20:15.161586 [ 4694 ] {6d1e5e2c-7b49-4888-b764-760200b04667} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44072) (comment: 01780_dict_get_or_null.sql) (in query: DROP DATABASE IF EXISTS test_069xrfrc SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.162857 [ 4694 ] {6d1e5e2c-7b49-4888-b764-760200b04667} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:15.191127 [ 7056 ] {8737d4cd-e469-4998-a877-43277da55e54} executeQuery: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53292) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO Disk('backups', '02843_backup_use_same_password_for_base_backup_test_3_inc_2_bad.zip') SETTINGS base_backup=Disk('backups', '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip'),password='password'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ZipArchiveReader::showError(String const&) const @ 0x000000002b5f9baa 5. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:186: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x000000002b5fce8f 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:347: DB::ZipArchiveReader::ReadBufferFromZipArchive::showError(String const&) const @ 0x000000002b5fda2d 7. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:243: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd7f6 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 9. ./build_docker/./src/Backups/BackupImpl.cpp:424: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf7bdc8 10. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf77095 11. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf75f27 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072c39 13. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c0719c6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 15. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf7f95a 16. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf7f673 17. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf4b80a 18. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4a221 19. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5ecfe 20. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56be3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 22. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.207761 [ 7056 ] {} TCPHandler: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ZipArchiveReader::showError(String const&) const @ 0x000000002b5f9baa 5. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:186: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x000000002b5fce8f 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:347: DB::ZipArchiveReader::ReadBufferFromZipArchive::showError(String const&) const @ 0x000000002b5fda2d 7. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:243: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd7f6 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 9. ./build_docker/./src/Backups/BackupImpl.cpp:424: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf7bdc8 10. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf77095 11. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf75f27 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072c39 13. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c0719c6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 15. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf7f95a 16. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf7f673 17. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf4b80a 18. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4a221 19. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5ecfe 20. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56be3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 22. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf479f3 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476eb 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.598258 [ 3863 ] {36454bd7-8fd7-4994-8bda-3ebfa31cbc0b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44110) (comment: 00386_long_in_pk.sh) (in query: select (c, d) in (select (c, d) from tab_00386) from tab_00386), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x0000000031b5e57b 10. DB::IOutputFormat::writePrefixIfNeeded() @ 0x000000001ae2e797 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:80: DB::IOutputFormat::work() @ 0x000000003184af47 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:15.604603 [ 3863 ] {36454bd7-8fd7-4994-8bda-3ebfa31cbc0b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x0000000031b5e57b 10. DB::IOutputFormat::writePrefixIfNeeded() @ 0x000000001ae2e797 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:80: DB::IOutputFormat::work() @ 0x000000003184af47 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:16.382284 [ 6249 ] {aec5dc05-26c7-4e5f-a4b8-051e61acfc5e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53162) (comment: 01231_operator_null_in.sql) (query 10, line 13) (in query: SELECT count() == 1 FROM null_in WHERE i not in (1, 3, NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c5ecdd8 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:20:16.416459 [ 6249 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c5ecdd8 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:16.466879 [ 4694 ] {02784_automatic_parallel_replicas-test_ozccaivw_whole_table_10M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=3): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/data.bin (position: 99316, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 18574e6fa182f4cc1797ef2d983fc80f821b80000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 3 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53382) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:20:16.497662 [ 4694 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=3): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/data.bin (position: 99316, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 18574e6fa182f4cc1797ef2d983fc80f821b80000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 3 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:17.692629 [ 4694 ] {02784_automatic_parallel_replicas-test_ozccaivw_whole_table_6M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=0): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/data.bin (position: 1522849, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a3786d4b9e6e6674012958cd713c44da821c80000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 46 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53490) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:20:17.714626 [ 4694 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=0): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/data.bin (position: 1522849, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a3786d4b9e6e6674012958cd713c44da821c80000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_13_13_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 46 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:17.840933 [ 6962 ] {6709ef48-1c4c-47ed-8943-3a5e3dffa078} BackupsWorker: Failed to restore from backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_3_inc_2.zip'): Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ZipArchiveReader::showError(String const&) const @ 0x000000002b5f9baa 5. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:186: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x000000002b5fce8f 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:347: DB::ZipArchiveReader::ReadBufferFromZipArchive::showError(String const&) const @ 0x000000002b5fda2d 7. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:243: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd7f6 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 9. ./build_docker/./src/Backups/BackupImpl.cpp:424: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf7bdc8 10. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf77095 11. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf75f27 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072c39 13. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c0719c6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 15. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf7f95a 16. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf7f673 17. ./build_docker/./src/Backups/BackupImpl.cpp:751: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf86ad9 18. ./build_docker/./src/Backups/BackupImpl.cpp:692: DB::BackupImpl::readFile(String const&) const @ 0x000000002bf86612 19. ./build_docker/./src/Backups/RestorerFromBackup.cpp:451: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c02a81e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c03579a 21. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (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&&) @ 0x000000002c034e79 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c027cee 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:397: DB::RestorerFromBackup::findTableInBackup(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c0282f8 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:366: DB::RestorerFromBackup::findDatabasesAndTablesInBackup() @ 0x000000002c02494f 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:154: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c021098 9. ./build_docker/./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&) @ 0x000000002bf4f389 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf47eb4 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476c8 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:17.856680 [ 6024 ] {6709ef48-1c4c-47ed-8943-3a5e3dffa078} executeQuery: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53530) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: RESTORE TABLE data AS data_2 FROM Disk('backups', '02843_backup_use_same_password_for_base_backup_test_3_inc_2.zip') SETTINGS password='password'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ZipArchiveReader::showError(String const&) const @ 0x000000002b5f9baa 5. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:186: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x000000002b5fce8f 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:347: DB::ZipArchiveReader::ReadBufferFromZipArchive::showError(String const&) const @ 0x000000002b5fda2d 7. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:243: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd7f6 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 9. ./build_docker/./src/Backups/BackupImpl.cpp:424: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf7bdc8 10. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf77095 11. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf75f27 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072c39 13. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c0719c6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 15. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf7f95a 16. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf7f673 17. ./build_docker/./src/Backups/BackupImpl.cpp:751: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf86ad9 18. ./build_docker/./src/Backups/BackupImpl.cpp:692: DB::BackupImpl::readFile(String const&) const @ 0x000000002bf86612 19. ./build_docker/./src/Backups/RestorerFromBackup.cpp:451: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c02a81e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c03579a 21. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:20:17.874573 [ 6024 ] {} TCPHandler: Code: 643. DB::Exception: Couldn't unpack zip archive '02843_backup_use_same_password_for_base_backup_test_3_inc_1.zip': Password is required. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ZipArchiveReader::showError(String const&) const @ 0x000000002b5f9baa 5. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:186: DB::ZipArchiveReader::HandleHolder::showError(String const&) const @ 0x000000002b5fce8f 6. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:347: DB::ZipArchiveReader::ReadBufferFromZipArchive::showError(String const&) const @ 0x000000002b5fda2d 7. ./build_docker/./src/IO/Archives/ZipArchiveReader.cpp:243: DB::ZipArchiveReader::ReadBufferFromZipArchive::ReadBufferFromZipArchive(DB::ZipArchiveReader::HandleHolder&&) @ 0x000000002b5fd7f6 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ZipArchiveReader::readFile(String const&, bool) @ 0x000000002b5f9e7d 9. ./build_docker/./src/Backups/BackupImpl.cpp:424: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf7bdc8 10. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf77095 11. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf75f27 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072c39 13. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c0719c6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 15. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf7f95a 16. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf7f673 17. ./build_docker/./src/Backups/BackupImpl.cpp:751: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf86ad9 18. ./build_docker/./src/Backups/BackupImpl.cpp:692: DB::BackupImpl::readFile(String const&) const @ 0x000000002bf86612 19. ./build_docker/./src/Backups/RestorerFromBackup.cpp:451: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c02a81e 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c03579a 21. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (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&&) @ 0x000000002c034e79 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c027cee 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:397: DB::RestorerFromBackup::findTableInBackup(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c0282f8 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:366: DB::RestorerFromBackup::findDatabasesAndTablesInBackup() @ 0x000000002c02494f 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:154: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c021098 9. ./build_docker/./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&) @ 0x000000002bf4f389 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf47eb4 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476c8 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.157078 [ 5480 ] {76e7f946-6830-4734-8ced-87d77eed6d1f} executeQuery: Code: 57. DB::Exception: Table test_13.test_02312 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53410) (comment: 02312_parquet_orc_arrow_names_tuples.sql) (query 14, line 17) (in query: create table test_02312 (a Nested(b Nested(c UInt32))) engine=File(Parquet);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.161419 [ 5480 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.test_02312 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.207269 [ 2824 ] {d8552343-bd47-492d-b224-f7028a49354c} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264bbf2a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.214783 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264bbf2a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.424099 [ 2824 ] {2e19cdf2-0f41-4fcb-8b20-ae0f24539d6f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264bba8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.443998 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264bba8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.600789 [ 2824 ] {9d60d962-2a72-498b-afe8-1348be0236c9} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000266d2e6a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.609928 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002453a8ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000266d2e6a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.762174 [ 3901 ] {bf62ee6a-04b3-4013-a1ab-4a2a2a6311da} executeQuery: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 1, line 1) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt16) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7dbaa 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:18.960430 [ 3901 ] {} TCPHandler: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7dbaa 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.125265 [ 4529 ] {1dd9337c-a930-46a9-8c2b-1f5f318bfd64} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 8.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51430) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:19.151458 [ 4529 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 8.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:19.149063 [ 3901 ] {b7d45465-8490-463f-be14-5282b9e96d9d} executeQuery: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 2, line 2) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` String, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c898a7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d2eb 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.172564 [ 3901 ] {} TCPHandler: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c898a7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d2eb 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.217853 [ 3025 ] {} test_tga1ryet.rmt (4138a690-907d-404b-9920-96bd07ae0f4f): Found 2 empty unexpected parts (probably some dropped parts were not cleaned up before restart): [0_0_0_1, 1_0_0_1] 2025.07.13 02:20:19.386944 [ 3901 ] {823df051-552f-4a25-abb8-854f94e33f66} executeQuery: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 3, line 3) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(is_deleted, is_deleted) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d529 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.394114 [ 3901 ] {} TCPHandler: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d529 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.506755 [ 3863 ] {02784_automatic_parallel_replicas-test_ozccaivw_whole_table_5M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=1): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_18_18_0/data.bin (position: 628979, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0084409b565d46092ad35bbc68ff6edf821a80000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_18_18_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 19 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53562) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:20:19.613159 [ 3863 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=1): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_18_18_0/data.bin (position: 628979, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0084409b565d46092ad35bbc68ff6edf821a80000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/3_18_18_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 19 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.620156 [ 5382 ] {73ac8816-c340-4e4a-8d4e-bcac829d5639} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:55556). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55556) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_ozccaivw`.`test_parallel_replicas_automatic_count` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2138 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.633625 [ 5382 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:55556). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2138 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.831285 [ 3901 ] {213f5c14-a21b-4f6a-a7e7-1452b95ec139} executeQuery: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 5, line 6) (in query: ALTER TABLE replacing MODIFY COLUMN ver String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.839392 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.855265 [ 10341 ] {906364a7-3b5d-4594-a432-42e684f3a636} executeQuery: Code: 701. DB::Exception: Requested cluster 'not_exists' not found. (CLUSTER_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51444) (comment: 03215_analyzer_replace_with_dummy_tables.sql) (query 2, line 3) (in query: SELECT 1 FROM ( SELECT number IN ( SELECT number FROM view( SELECT number FROM numbers(1) ) ) FROM t ) SETTINGS allow_experimental_parallel_reading_from_replicas = 1, cluster_for_parallel_replicas='not_exists', max_parallel_replicas = 2, allow_experimental_analyzer = 1, parallel_replicas_for_non_replicated_merge_tree = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/Context.cpp:4481: DB::Context::getCluster(String const&) const @ 0x000000002d4aad12 6. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:488: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d2e62 7. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95708 8. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.863627 [ 10341 ] {} TCPHandler: Code: 701. DB::Exception: Requested cluster 'not_exists' not found. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Interpreters/Context.cpp:4481: DB::Context::getCluster(String const&) const @ 0x000000002d4aad12 6. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:488: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d2e62 7. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95708 8. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:19.916909 [ 3060 ] {} test_tga1ryet.rmt1 (034f8c7f-22e5-45e3-accc-adb64c0a5b07): Found 1 empty unexpected parts (probably some dropped parts were not cleaned up before restart): [1_0_0_1] 2025.07.13 02:20:20.149594 [ 3901 ] {118a2d1d-21c7-4731-a607-da4823a1e8a2} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 7, line 8) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.163216 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.220766 [ 10341 ] {7b68e078-9c84-4bd3-9cec-d86acf0123be} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 16.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51524) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:20.239614 [ 6249 ] {9a5a330b-b44d-492c-9bbe-2e7cecda84b0} executeQuery: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51530) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Storages/ProjectionsDescription.cpp:424: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003036ee9c 6. ./build_docker/./src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c6082 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.241475 [ 10341 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 16.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:20.271195 [ 3901 ] {449358a6-e8d5-4043-90dc-e7fd8a896fa7} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 8, line 9) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted UInt16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.279671 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.304681 [ 6249 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Storages/ProjectionsDescription.cpp:424: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003036ee9c 6. ./build_docker/./src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c6082 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.405182 [ 3901 ] {87347743-1a87-4571-b6e8-b12b2e77a34a} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 9, line 10) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted Int8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.414629 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.629239 [ 3901 ] {047586fa-ed4c-4d65-9143-11151c77ac3a} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 10, line 11) (in query: ALTER TABLE replacing DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.634035 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.687290 [ 3901 ] {c691e6d8-1643-4696-8cbe-1bdefef57a78} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 11, line 12) (in query: ALTER TABLE replacing DROP COLUMN is_deleted;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.695406 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.792475 [ 3901 ] {8c27c710-fc61-495d-b102-b5c23e53ce37} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 12, line 13) (in query: ALTER TABLE replacing RENAME COLUMN ver TO ver2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.804409 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.873848 [ 3901 ] {0b128fdf-1735-4a90-bb29-4acf3a2abd4c} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 13, line 14) (in query: ALTER TABLE replacing RENAME COLUMN is_deleted TO is_deleted2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:20.879895 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.111528 [ 3901 ] {c4f2d0b8-d1df-4196-a248-02fc5206b183} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 14, line 16) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` Int16) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.135304 [ 3901 ] {} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.147721 [ 5380 ] {8d1fbf00-55ca-455d-809e-219fdf18ef4d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47310) (comment: 03088_analyzer_ambiguous_column_multi_call.sql) (query 2, line 4) (in query: DROP DATABASE IF EXISTS test_11), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.192047 [ 5380 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.251339 [ 3901 ] {af859435-6d86-4c80-8a11-b7fe39c2c2a9} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 15, line 17) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.256589 [ 4694 ] {3d028db8-6a7e-4825-95f1-7bdd13d7e9a4} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 32.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51588) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:21.256850 [ 3901 ] {} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.265292 [ 4694 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 32.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:21.384056 [ 3901 ] {d4310581-b0e7-47fa-9c35-7be9e89c06ab} executeQuery: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 16, line 18) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(not_existing) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c8944e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.391805 [ 3901 ] {} TCPHandler: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c8944e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.475970 [ 3885 ] {66eb8b4a-ef70-440e-9de3-3412ba9cfdfc} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51570) (comment: 03205_json_syntax.sql) (query 9, line 11) (in query: create table test (json JSON(a UInt32)) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.493985 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.676555 [ 3901 ] {a858f9ce-5d98-4d27-b620-8339af1e1415} executeQuery: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 18, line 21) (in query: ALTER TABLE collapsing MODIFY COLUMN sign String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.700962 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.769242 [ 3901 ] {fce03bcd-fac6-402c-8e09-bf5cb1a1f747} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 19, line 22) (in query: ALTER TABLE collapsing DROP COLUMN sign;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.776253 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.785095 [ 2824 ] {cb5b962e-f805-484e-8cef-c6cd276ea2c0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51642) (comment: 03088_analyzer_ambiguous_column_multi_call.sql) (query 2, line 4) (in query: DROP DATABASE IF EXISTS test_11), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.809809 [ 2824 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.876759 [ 3901 ] {48d23327-0727-43ee-bdde-af3d7ee55d1a} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 20, line 23) (in query: ALTER TABLE collapsing RENAME COLUMN sign TO sign2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:21.879032 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.010803 [ 3901 ] {65145e0b-eb4f-4518-8120-89cf0feb3451} executeQuery: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 21, line 24) (in query: ALTER TABLE collapsing MODIFY COLUMN sign MODIFY SETTING max_compress_block_size = 123456;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d9796f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdddca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.014211 [ 3901 ] {} TCPHandler: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d9796f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdddca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.069173 [ 2824 ] {73a2fe22-e864-4c09-9c39-ad083e3ce9cf} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 64.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51710) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:22.072681 [ 2824 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 64.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:22.234590 [ 3901 ] {a03af025-6a1b-4472-a1fe-da815180a72b} executeQuery: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53616) (comment: 03093_special_column_errors.sql) (query 22, line 26) (in query: CREATE TABLE versioned_collapsing_wrong (`key` Int64, `version` UInt8, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(sign, sign) ORDER BY key SETTINGS index_granularity = 31688, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9534109234809875, 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 = 349863130, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 495149, merge_max_block_size = 19399, old_parts_lifetime = 299., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4774386, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 86001, primary_key_compress_block_size = 96765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d5c4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.245718 [ 3901 ] {} TCPHandler: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d5c4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.615107 [ 4938 ] {68625495-7320-478d-9ef4-c83be1e8512b} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51754) (comment: 03254_merge_source_parts.sql) (query 2, line 2) (in query: CREATE TABLE test (x UInt8) ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.636341 [ 4938 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:22.950145 [ 4938 ] {df465ea5-fd10-4632-95a0-28c5bb0db44b} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 128.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51782) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:22.972850 [ 4938 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 128.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:23.668733 [ 2824 ] {0311e52f-f4f7-41db-9df6-60e5f30bd40b} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 256.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51852) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:23.680373 [ 2824 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 256.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:24.589657 [ 3815 ] {bee964a9-5b9e-4a42-b35a-9f894d551e1c} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 512.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51920) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:24.604172 [ 3815 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 512.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:24.608093 [ 5480 ] {02784_automatic_parallel_replicas-test_ozccaivw_pruning_1M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=2): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/1_2_2_0/data.bin (position: 463461, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: fd5903057fa9e4de062aa1fa7176a2b4821880000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/1_2_2_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 14 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51834) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE p != 3 SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x0000000030f4fdc6 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fb90 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:20:24.667363 [ 4142 ] {66dacc79-03a6-4032-a830-831d20b3dfdd} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:38134). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316adca3 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:24.712697 [ 5480 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=2): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/1_2_2_0/data.bin (position: 463461, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: fd5903057fa9e4de062aa1fa7176a2b4821880000000000100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/1_2_2_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 14 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c614703 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x0000000030f4fdc6 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fb90 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:25.603601 [ 6951 ] {02784_automatic_parallel_replicas-test_ozccaivw_pruning_500k_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=1): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/0_1_1_0/data.bin (position: 920906, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3fd10f4f822dc7a3bb351c624eede447824980000009200100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/0_1_1_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 28 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51962) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE p != 3 SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x0000000030f4fdc6 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fb90 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:20:25.634986 [ 4694 ] {db2e6afc-d990-4e33-bc02-d00d1b60c637} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 1.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52020) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:25.637715 [ 4694 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 1.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageStripeLog.cpp:190: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889c70 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:20:25.637815 [ 3766 ] {3687f7dd-b7e7-4fc3-b660-79d11e3bf780} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:37630). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37630) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_ozccaivw`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE `__table1`.`p` != 3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2138 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:20:25.642750 [ 6951 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=1): While reading or decompressing /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/0_1_1_0/data.bin (position: 920906, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3fd10f4f822dc7a3bb351c624eede447824980000009200100): (while reading column number): (while reading from part /var/lib/clickhouse/store/1d4/1d4a0002-44e2-4f53-aadb-b0accad5befc/0_1_1_0/ in table test_ozccaivw.test_parallel_replicas_automatic_count (1d4a0002-44e2-4f53-aadb-b0accad5befc) located on disk default of type local, from mark 28 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x0000000030f4fdc6 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fb90 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:25.648890 [ 3766 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:37630). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2138 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:20:25.976216 [ 2936 ] {} test_tga1ryet.rmt (4138a690-907d-404b-9920-96bd07ae0f4f): Found 2 empty unexpected parts (probably some dropped parts were not cleaned up before restart): [0_3_5_1, 1_2_4_1] 2025.07.13 02:20:26.021556 [ 3815 ] {3b07b4b1-3678-41a5-8528-b66435d2a1af} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'wow': In scope SELECT JSONExtract('{"hello":[{" wow ":"wtf"}]}', 'Tuple(hello Array(Tuple(` wow ` String)))') AS x, x.hello, tupleElement(x.hello[1], 'wow'). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51994) (comment: 03224_tuple_element_identifier.sql) (query 5, line 10) (in query: SELECT JSONExtract('{"hello":[{" wow ":"wtf"}]}', 'Tuple(hello Array(Tuple(` wow ` String)))') AS x, x.hello, x.hello[1].`wow`;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.048713 [ 3815 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'wow': In scope SELECT JSONExtract('{"hello":[{" wow ":"wtf"}]}', 'Tuple(hello Array(Tuple(` wow ` String)))') AS x, x.hello, tupleElement(x.hello[1], 'wow'). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.235033 [ 6951 ] {b2897765-7548-456e-a51b-a0033c9fd718} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.38 MiB (attempt to allocate chunk of 76.38 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52030) (comment: 01109_inflating_cross_join.sql) (query 3, line 4) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) n2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x000000002e461c46 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465c6d 12. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 13. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 14. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1628: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda2918 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.240552 [ 6951 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.38 MiB (attempt to allocate chunk of 76.38 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x000000002e461c46 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465c6d 12. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 13. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 14. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1628: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda2918 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.555563 [ 5480 ] {c606e292-d73c-4f1f-ab9a-0c0119e4d2eb} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52084) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889db5 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 16. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.583980 [ 5480 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::StripeLogSink::StripeLogSink(DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889db5 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x00000000308895d9 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageStripeLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030889426 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageStripeLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003087dc5b 16. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.636379 [ 3006 ] {} test_tga1ryet.rmt1 (034f8c7f-22e5-45e3-accc-adb64c0a5b07): Found 1 empty unexpected parts (probably some dropped parts were not cleaned up before restart): [1_2_4_1] 2025.07.13 02:20:26.698420 [ 6951 ] {d3bd19ec-f8e4-4004-9af1-92b7ef3896b9} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 15.26 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52030) (comment: 01109_inflating_cross_join.sql) (query 5, line 7) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) n2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:26.727791 [ 6951 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 15.26 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.177844 [ 5971 ] {b82552b5-3cb1-4023-9241-c9e7601be7e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52010) (comment: 03129_serial_test_zookeeper.sql) (query 5, line 8) (in query: SELECT generateSerialID();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.181181 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.271056 [ 5971 ] {e0439793-ad68-470a-ac9b-ff13c648805d} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID('x', 'y'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52010) (comment: 03129_serial_test_zookeeper.sql) (query 6, line 9) (in query: SELECT generateSerialID('x', 'y');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.276818 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID('x', 'y'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002accf6a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.426462 [ 5971 ] {091e6b44-3253-4fce-bfeb-a38c086258a4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: UInt8: In scope SELECT generateSerialID(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52010) (comment: 03129_serial_test_zookeeper.sql) (query 7, line 10) (in query: SELECT generateSerialID(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af98e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:27.434853 [ 5971 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: UInt8: In scope SELECT generateSerialID(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af98e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:27.518346 [ 5732 ] {7cecb5d4-833d-4b5d-bc90-84214fb3381b} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52150) (comment: 01674_where_prewhere_array_crash.sql) (query 3, line 3) (in query: select x from tab array join arr prewhere x != 0 where arr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca1678 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.521409 [ 5732 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca1678 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.529542 [ 10341 ] {924389d8-cc77-47fc-ae24-54245e58facb} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.29 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 4.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52188) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.540370 [ 5971 ] {9b817d8c-4c94-4858-a251-eadae8f5c7c1} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: String: In scope SELECT generateSerialID(materialize('x')). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52010) (comment: 03129_serial_test_zookeeper.sql) (query 8, line 11) (in query: SELECT generateSerialID(materialize('x'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af98e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:27.546530 [ 5971 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: String: In scope SELECT generateSerialID(materialize('x')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af98e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:27.554413 [ 10341 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.29 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 4.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.687827 [ 5732 ] {30d79fc5-902d-44cc-b893-2844011a91bf} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52150) (comment: 01674_where_prewhere_array_crash.sql) (query 4, line 4) (in query: select x from tab array join arr prewhere arr where x != 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca15bb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.708943 [ 5732 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca15bb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.782539 [ 5971 ] {58140026-6b88-4db5-bfed-ba137dbd53e1} executeQuery: Code: 36. DB::Exception: Series name 'abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij' is too long. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52010) (comment: 03129_serial_test_zookeeper.sql) (query 9, line 12) (in query: SELECT generateSerialID('abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af98840 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:27.787076 [ 5971 ] {} TCPHandler: Code: 36. DB::Exception: Series name 'abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij' is too long. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af98840 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:28.464788 [ 5971 ] {034d85f8-6501-4212-b611-b9b369dfd32c} executeQuery: Code: 290. DB::Exception: Too many series created by generateSerialID function, maximum: 3. This is controlled by the `max_autoincrement_series` setting. (LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52010) (comment: 03129_serial_test_zookeeper.sql) (query 12, line 18) (in query: SELECT generateSerialID('a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long const&) @ 0x000000001af9940f 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af98183 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:28.469069 [ 5971 ] {} TCPHandler: Code: 290. DB::Exception: Too many series created by generateSerialID function, maximum: 3. This is controlled by the `max_autoincrement_series` setting. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long const&) @ 0x000000001af9940f 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af98183 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:28.573026 [ 5732 ] {a42ede77-d1bf-477e-9d12-e7b49ac3162b} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.75 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 8.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52252) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:28.597596 [ 5732 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.75 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 8.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:29.471484 [ 6024 ] {e30ace09-7401-4967-9f21-c7a8e2566152} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39846) (comment: 00830_join_overwrite.sql) (in query: DROP DATABASE IF EXISTS test_7cuf049w SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:29.473675 [ 6024 ] {e30ace09-7401-4967-9f21-c7a8e2566152} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:29.508533 [ 4468 ] {744f2d53-b31e-4227-9569-35bc83fbafdd} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 16.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50850) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:29.519000 [ 4468 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 16.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:30.447692 [ 5379 ] {d3e1e58b-97cb-4dd1-bcc4-4dd28a72beae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57344) (comment: 03277_json_subcolumns_in_primary_key.gen.sql) (query 127, line 158) (in query: select * from test order by json.a desc, id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 13. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:190: DB::SerializationObject::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c6264bb 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 2025.07.13 02:20:30.484796 [ 5379 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 13. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:190: DB::SerializationObject::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c6264bb 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:30.512478 [ 4694 ] {24942cf1-7364-4283-bfe0-02fe3ec859ff} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 32.03 MiB (attempt to allocate chunk of 7.07 MiB bytes), maximum: 32.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50898) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:30.516014 [ 4694 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 32.03 MiB (attempt to allocate chunk of 7.07 MiB bytes), maximum: 32.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:31.558306 [ 5971 ] {02784_automatic_parallel_replicas-test_ozccaivw_limit_500k_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50984) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM (SELECT number FROM test_parallel_replicas_automatic_count LIMIT 1_000_000) SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1044: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddace34 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 13. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:31.604804 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1044: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddace34 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 13. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:32.025939 [ 5971 ] {59b1431b-f584-44ad-81f6-fa0c71fdad44} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53510) (comment: 01058_zlib_ng_level1_bug.sh) (in query: SELECT * FROM numbers(34546)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x0000000031b5e57b 10. DB::IOutputFormat::writePrefixIfNeeded() @ 0x000000001ae2e797 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:80: DB::IOutputFormat::work() @ 0x000000003184af47 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:32.044518 [ 5971 ] {59b1431b-f584-44ad-81f6-fa0c71fdad44} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x0000000031b5e57b 10. DB::IOutputFormat::writePrefixIfNeeded() @ 0x000000001ae2e797 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:80: DB::IOutputFormat::work() @ 0x000000003184af47 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:32.922154 [ 6024 ] {644f7622-f0ec-40e6-ae7e-4e35990605c8} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.14 MiB (attempt to allocate chunk of 1.07 MiB), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50858) (comment: 00823_sequence_match_dfa.sql) (query 7, line 26) (in query: SELECT 'ABBC' FROM sequence GROUP BY userID HAVING sequenceMatch('(?1).*(?2).*(?3).*(?4)')(EventTime, eventType = 'A', eventType = 'B', eventType = 'B',eventType = 'C');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. ./src/Common/Allocator.h:112: void DB::PODArrayBase<16ul, 64ul, AllocatorWithStackMemory, 64ul, 8ul>, 0ul, 0ul>::realloc<>(unsigned long) @ 0x0000000024b9905d 10. ./src/Common/PODArray.h:441: void DB::PODArray>, 64ul, AllocatorWithStackMemory, 64ul, 8ul>, 0ul, 0ul>::emplace_back const&>(unsigned long const&, std::bitset<32ul> const&) @ 0x0000000025ad10ce 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceMatch.cpp:75: DB::(anonymous namespace)::AggregateFunctionSequenceBase, DB::(anonymous namespace)::AggregateFunctionSequenceMatch>>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000025a347ba 12. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper>>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000025a38144 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6c2dd2 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1260: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002d6c293d 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d894270 16. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d891e9d 17. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d74fa36 18. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6bfdc9 19. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7b52 20. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:33.003692 [ 6024 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.14 MiB (attempt to allocate chunk of 1.07 MiB), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. ./src/Common/Allocator.h:112: void DB::PODArrayBase<16ul, 64ul, AllocatorWithStackMemory, 64ul, 8ul>, 0ul, 0ul>::realloc<>(unsigned long) @ 0x0000000024b9905d 10. ./src/Common/PODArray.h:441: void DB::PODArray>, 64ul, AllocatorWithStackMemory, 64ul, 8ul>, 0ul, 0ul>::emplace_back const&>(unsigned long const&, std::bitset<32ul> const&) @ 0x0000000025ad10ce 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceMatch.cpp:75: DB::(anonymous namespace)::AggregateFunctionSequenceBase, DB::(anonymous namespace)::AggregateFunctionSequenceMatch>>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000025a347ba 12. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper>>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000025a38144 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6c2dd2 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1260: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002d6c293d 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d894270 16. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d891e9d 17. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d74fa36 18. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6bfdc9 19. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7b52 20. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:34.450694 [ 6126 ] {91972147-b506-42e3-b7db-654a4eafe43a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 8.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51142) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:34.454270 [ 6126 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 8.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:35.209781 [ 5379 ] {121f97e8-bcac-496c-8630-4d43a027375f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 16.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51192) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:35.217174 [ 5379 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 16.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:35.622077 [ 4468 ] {cc4464e7-ac59-4862-af63-a0df7fccbecd} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 (BADREQUEST): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53652) (comment: 01071_http_header_exception_code.sh) (in query: BADREQUEST ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:20:35.628077 [ 4468 ] {cc4464e7-ac59-4862-af63-a0df7fccbecd} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 (BADREQUEST): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:35.774482 [ 3863 ] {a6cb8de5-48d0-4232-b211-09e0bbed4128} executeQuery: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51200) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 1, line 1) (in query: SELECT lambda(tuple(1), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:35.779449 [ 3665 ] {8211fef1-a420-4790-a644-0a9a2d797b4d} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_7.t_async_insert_params (id) FORMAT Values' with query id 1f4020bb-9c13-42a8-b964-dbe318eae7b4. DB::Exception: Value Hello cannot be parsed as UInt64 for query parameter 'p1' because it isn't parsed completely: only 0 of 5 bytes was parsed: 2025.07.13 02:20:35.790565 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:35.828494 [ 3863 ] {1907df69-62c6-46ef-9315-d21a90e72e2d} executeQuery: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51200) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 2, line 2) (in query: SELECT lambda(tuple(1, 2), materialize(1) + x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:35.834010 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:35.848091 [ 3766 ] {1f4020bb-9c13-42a8-b964-dbe318eae7b4} executeQuery: Code: 457. DB::Exception: Value Hello cannot be parsed as UInt64 for query parameter 'p1' because it isn't parsed completely: only 0 of 5 bytes was parsed: : While executing WaitForAsyncInsert. (BAD_QUERY_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51182) (comment: 03228_async_insert_query_params_bad_type.sql) (query 6, line 10) (in query: INSERT INTO t_async_insert_params VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&, unsigned long&&, unsigned long&&, String&&) @ 0x000000002e28f5b7 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e28e1e3 6. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e27829e 7. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 8. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000031d4822c 9. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d436f9 10. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 15. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 16. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 17. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:35.881655 [ 3766 ] {} TCPHandler: Code: 457. DB::Exception: Value Hello cannot be parsed as UInt64 for query parameter 'p1' because it isn't parsed completely: only 0 of 5 bytes was parsed: : While executing WaitForAsyncInsert. (BAD_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&, unsigned long&&, unsigned long&&, String&&) @ 0x000000002e28f5b7 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e28e1e3 6. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e27829e 7. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 8. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000031d4822c 9. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d436f9 10. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 15. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 16. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 17. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:317: DB::AsynchronousInsertQueue::scheduleDataProcessingJob(DB::AsynchronousInsertQueue::InsertQuery const&, std::unique_ptr>, std::shared_ptr, unsigned long) @ 0x000000002d3fe6d9 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:532: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d402f05 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d4014ef 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:20:36.087649 [ 6942 ] {bd6d39a5-c719-4c30-8bfd-ef40d811b003} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_7.t_async_insert_params (id) FORMAT Values' with query id 7f6bfe82-9fa7-4256-a6f2-e09a00030b87. DB::Exception: Cannot convert string 'Hello' to type UInt64 2025.07.13 02:20:36.137806 [ 3766 ] {7f6bfe82-9fa7-4256-a6f2-e09a00030b87} executeQuery: Code: 53. DB::Exception: Cannot convert string 'Hello' to type UInt64: While executing WaitForAsyncInsert. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51182) (comment: 03228_async_insert_query_params_bad_type.sql) (query 7, line 11) (in query: INSERT INTO t_async_insert_params VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:555: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000031d482b5 8. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d436f9 9. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 14. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 16. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:36.143587 [ 3766 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'Hello' to type UInt64: While executing WaitForAsyncInsert. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:555: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000031d482b5 8. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d436f9 9. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 14. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 16. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:36.196326 [ 4477 ] {650448a6-ee81-4456-9808-a8fc86a6035a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 32.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51234) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:36.238641 [ 4477 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 32.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:36.501128 [ 3665 ] {c3c15204-e144-4d39-ac74-b45319fb462b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_7.t_async_insert_params (id) FORMAT Values' with query id 4757f50b-4ede-415c-8e7f-cd15abf484b1. DB::Exception: Value Hello cannot be parsed as UInt64 for query parameter 'p1' because it isn't parsed completely: only 0 of 5 bytes was parsed: 2025.07.13 02:20:36.506051 [ 3766 ] {4757f50b-4ede-415c-8e7f-cd15abf484b1} executeQuery: Code: 457. DB::Exception: Value Hello cannot be parsed as UInt64 for query parameter 'p1' because it isn't parsed completely: only 0 of 5 bytes was parsed: : While executing WaitForAsyncInsert. (BAD_QUERY_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51182) (comment: 03228_async_insert_query_params_bad_type.sql) (query 9, line 15) (in query: INSERT INTO t_async_insert_params VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&, unsigned long&&, unsigned long&&, String&&) @ 0x000000002e28f5b7 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e28e1e3 6. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e27829e 7. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 8. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000031d4822c 9. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d436f9 10. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 15. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 16. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 17. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:36.510425 [ 3766 ] {} TCPHandler: Code: 457. DB::Exception: Value Hello cannot be parsed as UInt64 for query parameter 'p1' because it isn't parsed completely: only 0 of 5 bytes was parsed: : While executing WaitForAsyncInsert. (BAD_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&, unsigned long&&, unsigned long&&, String&&) @ 0x000000002e28f5b7 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e28e1e3 6. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e27829e 7. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 8. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000031d4822c 9. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d436f9 10. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 15. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 16. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 17. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:36.562097 [ 4142 ] {914dd2e3-fa12-4555-856a-5a4b71145e5e} DynamicQueryHandler: Code: 271. DB::Exception: Can't decompress data: header is corrupt with compressed block size 0. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:128: DB::ICompressionCodec::readCompressedBlockSize(char const*) const @ 0x0000000032e0416e 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:157: DB::readHeaderAndGetCodecAndSize(char const*, char8_t, std::shared_ptr&, unsigned long&, unsigned long&, bool, bool) @ 0x0000000032da8a76 7. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:185: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7cf3 8. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:12: DB::CompressedReadBuffer::nextImpl() @ 0x0000000032da702e 9. DB::ReadBuffer::next() @ 0x0000000017e75832 10. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000023b2a091 11. DB::ReadBuffer::next() @ 0x0000000017e75832 12. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x000000002d415020 13. DB::ReadBuffer::next() @ 0x0000000017e75832 14. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b37a0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:37.102172 [ 6024 ] {4c1c064c-a802-4699-bad0-f013b5e0f54f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 64.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51290) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:37.132285 [ 6024 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 64.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:38.023310 [ 3452 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4a69f8fa-bcc6-4626-8de6-91bc9307eaf5::10_2_2_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:38.068007 [ 6126 ] {7f2a1da2-2be1-486b-b3e0-bd5da79666e6} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 128.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51322) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:38.102161 [ 6126 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 128.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:38.790146 [ 4142 ] {cad1b87d-0138-4df8-8d3e-76b11eb6938f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 256.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56240) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:38.810298 [ 4142 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 256.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:39.021120 [ 4142 ] {651e1005-3576-479a-a86d-8769718177f1} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47400) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x00000000322574d4 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000032255477 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032253779 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.024356 [ 4142 ] {651e1005-3576-479a-a86d-8769718177f1} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x00000000322574d4 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000032255477 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032253779 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:39.223378 [ 4694 ] {cc64c2e4-cf4c-46cd-b645-916a69b4d61d} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47430) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.235269 [ 4694 ] {cc64c2e4-cf4c-46cd-b645-916a69b4d61d} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:39.456831 [ 3766 ] {61514467-8cd0-4b6d-8eff-fe50af267cc3} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47440) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.469654 [ 3766 ] {61514467-8cd0-4b6d-8eff-fe50af267cc3} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:39.512137 [ 5379 ] {df779764-5dfc-44ac-b1b3-86651c706487} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 512.00 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56278) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:39.534465 [ 5379 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 512.00 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:39.638883 [ 10341 ] {05ccce78-0f8d-4beb-9ba4-ec80e051af7a} executeQuery: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00933_alter_ttl.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_32445sha.ttl (MODIFY TTL a)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c068 6. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082d386 7. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c7948 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 16. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 17. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.674819 [ 10341 ] {05ccce78-0f8d-4beb-9ba4-ec80e051af7a} executeQuery: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51252) (comment: 00933_alter_ttl.sql) (query 12, line 16) (in query: alter table ttl modify ttl a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c068 6. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082d386 7. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c7948 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 16. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 17. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.678171 [ 10341 ] {} TCPHandler: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c068 6. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082d386 7. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c7948 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 16. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 17. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.862649 [ 4938 ] {385532b5-0f1e-4097-9b58-4c9022292661} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47462) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.873341 [ 4938 ] {385532b5-0f1e-4097-9b58-4c9022292661} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:39.964797 [ 10341 ] {52fe0ee4-6444-452d-b8d5-8d84c4818a1e} executeQuery: Code: 57. DB::Exception: Table test_32445sha.ttl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00933_alter_ttl.sql) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_32445sha.ttl UUID '4d0fb34d-8d5f-433d-ab81-2ca58841a961' (`d` Date, `a` Int32) ENGINE = MergeTree PARTITION BY toDayOfMonth(d) ORDER BY tuple() SETTINGS remove_empty_parts = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:39.989294 [ 10341 ] {52fe0ee4-6444-452d-b8d5-8d84c4818a1e} executeQuery: Code: 57. DB::Exception: Table test_32445sha.ttl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51252) (comment: 00933_alter_ttl.sql) (query 14, line 20) (in query: create table ttl (d Date, a Int) engine = MergeTree order by tuple() partition by toDayOfMonth(d) settings remove_empty_parts = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:40.005524 [ 10341 ] {} TCPHandler: Code: 57. DB::Exception: Table test_32445sha.ttl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:40.240120 [ 6024 ] {ec5266c7-7514-4c6b-b14e-853a7c425bf6} executeQuery: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('32.32', 'Float32'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 22, line 29) (in query: -- Max number of decimal fractional digits is defined as 77 for Int/UInt/Decimal and 60 for Float. -- These values shall work OK. SELECT toDecimalString('32.32'::Float32, 61);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000020ada2af 5. void DB::(anonymous namespace)::FunctionToDecimalString::format(float, DB::WriteBuffer&, char8_t) @ 0x0000000020ad96d2 6. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020acd8b9 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:40.246898 [ 6024 ] {} TCPHandler: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('32.32', 'Float32'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000020ada2af 5. void DB::(anonymous namespace)::FunctionToDecimalString::format(float, DB::WriteBuffer&, char8_t) @ 0x0000000020ad96d2 6. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020acd8b9 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:40.280536 [ 4694 ] {e5c7b7c0-4d46-4e86-88bc-6c40fe4dbb95} executeQuery: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56290) (comment: 02706_array_map_tuples.sql) (query 4, line 5) (in query: WITH [(1, 2)] AS arr1 SELECT arrayMap((x, y, z) -> (y, x, z), arr1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f1af4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38c24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:40.285702 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f1af4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38c24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:40.335933 [ 3815 ] {a7f85352-6e26-4776-8d68-427e95f49558} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 1.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56316) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:40.355904 [ 3815 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.05 MiB (attempt to allocate chunk of 1.05 MiB bytes), maximum: 1.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x0000000030506886 17. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::StorageLog::saveFileSizes(std::unique_lock const&) @ 0x000000003085d686 18. ./build_docker/./src/Storages/StorageLog.cpp:319: DB::LogSink::LogSink(DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x000000003087672f 19. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::unique_lock, std::allocator, 0>(std::allocator, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030876099 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageLog&, std::shared_ptr const&, std::unique_lock, 0>(std::allocator const&, DB::StorageLog&, std::shared_ptr const&, std::unique_lock&&) @ 0x0000000030875ee6 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::StorageLog::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030863bfb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:40.363389 [ 6024 ] {cb3dac4c-ce30-48fd-9322-91927e02855a} executeQuery: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('64.64', 'Float64'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 23, line 32) (in query: SELECT toDecimalString('64.64'::Float64, 61);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000020ada2af 5. void DB::(anonymous namespace)::FunctionToDecimalString::format(double, DB::WriteBuffer&, char8_t) @ 0x0000000020ad99c0 6. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ace162 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:40.368591 [ 4694 ] {909a7b47-2dff-450b-bf1d-f3478beeddf7} executeQuery: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56290) (comment: 02706_array_map_tuples.sql) (query 5, line 6) (in query: WITH [1, 2] AS arr1 SELECT arrayMap((x, y) -> (y, x), arr1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f1af4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38c24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:40.388918 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f1af4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38c24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:40.394726 [ 6024 ] {} TCPHandler: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('64.64', 'Float64'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000020ada2af 5. void DB::(anonymous namespace)::FunctionToDecimalString::format(double, DB::WriteBuffer&, char8_t) @ 0x0000000020ad99c0 6. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ace162 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:20:40.633562 [ 6024 ] {f23cf3c1-499e-41ac-91d3-31cca56e4ed0} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('88', 'UInt8'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 24, line 33) (in query: SELECT toDecimalString('88'::UInt8, 78);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ad0b72 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:20:40.638148 [ 6024 ] {} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('88', 'UInt8'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ad0b72 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:20:40.748961 [ 6024 ] {4d20265b-769a-4c64-904b-b5dcd7ff0e13} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('646464', 'Int256'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 25, line 34) (in query: SELECT toDecimalString('646464'::Int256, 78);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ad0cf2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:20:40.763879 [ 6024 ] {} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('646464', 'Int256'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ad0cf2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:20:40.893211 [ 6024 ] {f54f5f75-f04f-4a8e-9f1b-5eaca1586b38} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested for Decimal, must not be more than 77: In scope SELECT toDecimalString(CAST('-128.789323123321329854641231237893231233213298546', 'Decimal256(45)'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 26, line 35) (in query: SELECT toDecimalString('-128.789323123321329854641231237893231233213298546'::Decimal256(45), 78);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ad14bf 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:20:40.898930 [ 6024 ] {} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested for Decimal, must not be more than 77: In scope SELECT toDecimalString(CAST('-128.789323123321329854641231237893231233213298546', 'Decimal256(45)'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ad14bf 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:20:41.081680 [ 6024 ] {a7dd110e-6370-46e1-ac31-4f4df90046e3} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: UInt8: In scope SELECT toDecimalString(CAST('256.256', 'Decimal256(45)'), *). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 27, line 37) (in query: -- wrong types: #52407 and similar SELECT toDecimalString('256.256'::Decimal256(45), *);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ad7bd7 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:41.104909 [ 6024 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: UInt8: In scope SELECT toDecimalString(CAST('256.256', 'Decimal256(45)'), *). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ad7bd7 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:41.173354 [ 3815 ] {6c499dc3-1fa2-42eb-9806-edb0bb995b6d} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47524) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.176521 [ 3815 ] {6c499dc3-1fa2-42eb-9806-edb0bb995b6d} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:41.189124 [ 6024 ] {c9371fb9-0e5b-4a73-b453-8c9beb88edc7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: String: In scope SELECT toDecimalString(CAST('128.128', 'Decimal128(30)'), 'str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 28, line 39) (in query: SELECT toDecimalString('128.128'::Decimal128(30), 'str');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ad7bd7 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:41.194016 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: String: In scope SELECT toDecimalString(CAST('128.128', 'Decimal128(30)'), 'str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ad7bd7 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:20:41.213631 [ 6951 ] {a706d762-efec-439b-9500-dfb16fe0dc91} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.28 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 2.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56364) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.242246 [ 6951 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.28 MiB (attempt to allocate chunk of 1.12 MiB bytes), maximum: 2.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.296511 [ 6024 ] {e5daf807-88c0-4575-a2ea-7b8f309fb7c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 29, line 40) (in query: SELECT toDecimalString('64.64'::Decimal64(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.314018 [ 6024 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.428669 [ 6024 ] {235b264b-16b2-481a-9965-f6588f37a389} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)'), 3, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 02676_to_decimal_string.sql) (query 30, line 41) (in query: SELECT toDecimalString('64.64'::Decimal64(10), 3, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.450397 [ 6024 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)'), 3, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.874724 [ 3815 ] {a8f512fa-b14f-4a5b-a076-9bacea85c08f} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47544) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:41.880198 [ 3815 ] {a8f512fa-b14f-4a5b-a076-9bacea85c08f} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:42.192478 [ 3766 ] {b4824bcc-f117-4b4d-8373-e230f204b871} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.52 MiB (attempt to allocate chunk of 1.11 MiB bytes), maximum: 4.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56438) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.201936 [ 3766 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.52 MiB (attempt to allocate chunk of 1.11 MiB bytes), maximum: 4.00 MiB.: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffafc47 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x00000000322582fc 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.512604 [ 5380 ] {b71d5157-718b-4c4a-b867-d19490c3cd08} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56442) (comment: 02996_nullable_arrayReduce.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/59600 SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.513963 [ 5379 ] {ae1e930d-01c0-4177-8d98-144c5958b4d7} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47572) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.520014 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.520179 [ 5379 ] {ae1e930d-01c0-4177-8d98-144c5958b4d7} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:42.676313 [ 5380 ] {e17a1e50-f2fa-40e5-81c4-63c88804492c} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56442) (comment: 02996_nullable_arrayReduce.sql) (query 2, line 3) (in query: SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.682281 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.797230 [ 5380 ] {9a950727-9f4e-4fe5-9a4c-00f4140de5d6} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56442) (comment: 02996_nullable_arrayReduce.sql) (query 3, line 4) (in query: SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.803500 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:42.982489 [ 5380 ] {67351130-2d64-49a3-bd86-db3dfb0fd2ae} executeQuery: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56442) (comment: 02996_nullable_arrayReduce.sql) (query 4, line 5) (in query: SELECT arrayReduce('any', toNullable(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x00000000208866ef 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fcb5 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.026709 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x00000000208866ef 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fcb5 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.107979 [ 5380 ] {5dea3331-a641-454c-b16b-1d52435d880a} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56442) (comment: 02996_nullable_arrayReduce.sql) (query 5, line 6) (in query: SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.110959 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000002309fec4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.391997 [ 3885 ] {1e1620b1-f218-4f46-99ad-15b4863b481b} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 15.50 MiB (attempt to allocate chunk of 7.63 MiB bytes), maximum: 8.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56504) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.397113 [ 3885 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 15.50 MiB (attempt to allocate chunk of 7.63 MiB bytes), maximum: 8.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.798321 [ 3863 ] {5228d606-9a89-46f1-83ce-75e457f2fe4b} executeQuery: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51224) (comment: 03032_storage_memory_modify_settings.sql) (query 50, line 70) (in query: ALTER TABLE memory MODIFY SETTING min_rows_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x000000003034b38f 6. ./build_docker/./src/Storages/StorageMemory.cpp:326: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304f3d86 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.803411 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x000000003034b38f 6. ./build_docker/./src/Storages/StorageMemory.cpp:326: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304f3d86 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.827043 [ 5379 ] {da75be5f-97b3-437f-b028-701b9c2ae7e2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.89 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47592) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.844458 [ 5379 ] {da75be5f-97b3-437f-b028-701b9c2ae7e2} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.89 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:43.897704 [ 3863 ] {9b288520-0f9f-45ee-9d0a-84b51dd56eb2} executeQuery: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51224) (comment: 03032_storage_memory_modify_settings.sql) (query 51, line 71) (in query: ALTER TABLE memory MODIFY SETTING min_bytes_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x000000003034b31e 6. ./build_docker/./src/Storages/StorageMemory.cpp:326: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304f3d86 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:43.904030 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x000000003034b31e 6. ./build_docker/./src/Storages/StorageMemory.cpp:326: DB::StorageMemory::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304f3d86 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:20:44.033456 [ 10341 ] {84ce326d-beac-4990-8b2b-6bc940701979} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56496) (comment: 02425_categorical_information_value_properties.sql) (query 6, line 6) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((NULL, 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027e79fbe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:119: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6919 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:44.038866 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027e79fbe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:119: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6919 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:44.336915 [ 3885 ] {06787c1d-c2df-4d4c-bd4c-ba35ec36ca1f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 16.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 16.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56564) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:44.341408 [ 3885 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 16.06 MiB (attempt to allocate chunk of 8.19 MiB bytes), maximum: 16.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x000000002df984be 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x000000002df97276 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x000000002dcfd5b8 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:45.088001 [ 10341 ] {ebffd74f-e8a8-49c1-a5c7-321e4547de18} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56496) (comment: 02425_categorical_information_value_properties.sql) (query 12, line 12) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((NULL, NULL));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027e79fbe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:119: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6919 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:45.132018 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027e79fbe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:119: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6919 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:20:45.299744 [ 5379 ] {072fc079-cf77-4026-8be8-a032b70ef245} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.89 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47638) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:45.314422 [ 5379 ] {072fc079-cf77-4026-8be8-a032b70ef245} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.89 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:45.337182 [ 4477 ] {af14b835-86bb-49e1-aa79-b1f69918670d} PushingToViews: Failed to push block to view test_13.view (6b8a7bfb-a964-43df-9e81-389b4a564333), Target table 'test_13.dst' of view 'test_13.view' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.07.13 02:20:45.374669 [ 4477 ] {af14b835-86bb-49e1-aa79-b1f69918670d} executeQuery: Code: 60. DB::Exception: Target table 'test_13.dst' of view 'test_13.view' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56608) (comment: 03210_dynamic_squashing.sql) (query 5, line 10) (in query: insert into test select multiIf(number < 1000, NULL::Dynamic(max_types=1), number < 3000, range(number % 5)::Dynamic(max_types=1), number::Dynamic(max_types=1)) from numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./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) @ 0x0000000031efbeaf 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:45.411143 [ 4477 ] {} TCPHandler: Code: 60. DB::Exception: Target table 'test_13.dst' of view 'test_13.view' 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./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) @ 0x0000000031efbeaf 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:45.450661 [ 5380 ] {28b37568-7ed2-49b8-b80a-3891847af125} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 32.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 32.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56636) (comment: 01383_log_broken_table.sh) (query 1, line 1) (in query: INSERT INTO log SELECT number, number, number FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageLog.cpp:365: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x00000000308735fd 17. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::pair::pair[abi:ne190107] const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&, 0ul, 0ul, 1ul, 2ul, 3ul, 4ul>(std::piecewise_construct_t, std::tuple&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&, std::__tuple_indices<0ul>, std::__tuple_indices<0ul, 1ul, 2ul, 3ul, 4ul>) @ 0x0000000030873414 18. ./contrib/llvm-project/libcxx/include/__utility/pair.h:254: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000003087328b 19. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>, bool> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__emplace_unique_key_args, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(String const&, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000030872f5d 20. ./contrib/llvm-project/libcxx/include/map:1224: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003086b2dd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x000000003085b07a 24. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x000000003085ace2 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 2025.07.13 02:20:45.451497 [ 5380 ] {28b37568-7ed2-49b8-b80a-3891847af125} FileChecker: Will truncate file store/1ae/1ae80ce4-6df5-4c17-bf23-270c5eb3b83b/x.bin that has size 3145728 to size 0 2025.07.13 02:20:45.452969 [ 5380 ] {28b37568-7ed2-49b8-b80a-3891847af125} FileChecker: Will truncate file store/1ae/1ae80ce4-6df5-4c17-bf23-270c5eb3b83b/y.bin that has size 3145728 to size 0 2025.07.13 02:20:45.477333 [ 5380 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 32.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 32.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/StorageLog.cpp:365: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x00000000308735fd 17. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::pair::pair[abi:ne190107] const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&, 0ul, 0ul, 1ul, 2ul, 3ul, 4ul>(std::piecewise_construct_t, std::tuple&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&, std::__tuple_indices<0ul>, std::__tuple_indices<0ul, 1ul, 2ul, 3ul, 4ul>) @ 0x0000000030873414 18. ./contrib/llvm-project/libcxx/include/__utility/pair.h:254: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000003087328b 19. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>, bool> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__emplace_unique_key_args, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(String const&, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000030872f5d 20. ./contrib/llvm-project/libcxx/include/map:1224: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003086b2dd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x000000003085b07a 24. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x000000003085ace2 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:20:46.490136 [ 3815 ] {e783ecd7-7865-4ebb-bcc4-24a84ad9d7fc} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.89 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47694) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:20:46.499559 [ 3815 ] {e783ecd7-7865-4ebb-bcc4-24a84ad9d7fc} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.89 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3fe44f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd88e 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:48.149998 [ 5480 ] {ab841b47-4eea-4115-a52a-f64118ee3db5} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_uzeqwyet.test_constraints (ea1e9e59-fa45-4ba2-bb02-82f0fcdf30b5) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56834) (comment: 00952_basic_constraints.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:48.161319 [ 5480 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_uzeqwyet.test_constraints (ea1e9e59-fa45-4ba2-bb02-82f0fcdf30b5) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:48.166727 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:48.171478 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:20:48.187616 [ 3885 ] {4d044dca-7d13-4b62-83a3-edb75a1dcb74} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56774) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:20:48.294808 [ 3885 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:49.789688 [ 5379 ] {03502d57-147d-44b0-8ad3-c6d65cd39d76} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56766) (comment: 03224_nested_json_merges_new_type_in_shared_data.sql) (query 11, line 12) (in query: select distinct JSONSharedDataPaths(arrayJoin(json.a[])) as path from test order by path;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c667b05 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:20:49.811824 [ 5379 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c667b05 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:49.867894 [ 4477 ] {03436c03-6f84-4e3f-9190-824e92e19a07} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_uzeqwyet.test_constraints (e58f025a-d339-438e-a8e7-4562d33ae2c6) is violated at row 1. Expression: (b > 10). Column values: b = 2. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59740) (comment: 00952_basic_constraints.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:49.880939 [ 4477 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_uzeqwyet.test_constraints (e58f025a-d339-438e-a8e7-4562d33ae2c6) is violated at row 1. Expression: (b > 10). Column values: b = 2. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:50.026396 [ 5380 ] {2393aa41-85aa-4060-a61e-2780d91d9da7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55166) (comment: 03224_nested_json_merges_new_type_in_shared_data.sql) (in query: DROP DATABASE IF EXISTS test_kdwn5rn6 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:20:50.028767 [ 5380 ] {2393aa41-85aa-4060-a61e-2780d91d9da7} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:50.637953 [ 4142 ] {bd5b5686-b5eb-4954-9c16-6ef53dd5d86b} executeQuery: Code: 469. DB::Exception: Constraint `a_constraint` for table test_uzeqwyet.test_constraints (e58f025a-d339-438e-a8e7-4562d33ae2c6) is violated at row 2. Expression: (a < 10). Column values: a = 10. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59788) (comment: 00952_basic_constraints.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:50.649544 [ 4142 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `a_constraint` for table test_uzeqwyet.test_constraints (e58f025a-d339-438e-a8e7-4562d33ae2c6) is violated at row 2. Expression: (a < 10). Column values: a = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:51.007087 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:52.118725 [ 4663 ] {mysql:7:ce5bb4a3-48ec-4724-b2cc-a598c4b95ca6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47060) (in query: SELECT `b`, `c` FROM `test_13`.`foo` WHERE `c` != 'twee'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 12. ./build_docker/./src/Server/MySQLHandler.cpp:553: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x0000000031619b82 13. ./build_docker/./src/Server/MySQLHandler.cpp:318: DB::MySQLHandler::run() @ 0x0000000031611fbc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:20:52.145102 [ 4663 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 12. ./build_docker/./src/Server/MySQLHandler.cpp:553: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x0000000031619b82 13. ./build_docker/./src/Server/MySQLHandler.cpp:318: DB::MySQLHandler::run() @ 0x0000000031611fbc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:52.786717 [ 6024 ] {aafe6d21-af2e-463f-b5f8-1e541a5e0803} executeQuery: Code: 57. DB::Exception: Table test_7.t_optimize_level already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59712) (comment: 03283_optimize_on_insert_level.sql) (query 14, line 25) (in query: CREATE TABLE t_optimize_level (`a` UInt64, `b` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/{database}/03283_optimize_on_insert_level', '1') ORDER BY a SETTINGS index_granularity = 1, 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 = 196770868, compact_parts_max_bytes_to_buffer = 2860639, compact_parts_max_granules_to_buffer = 62, compact_parts_merge_max_bytes_to_prefetch_part = 18114197, merge_max_block_size = 14929, old_parts_lifetime = 261., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 75, min_merge_bytes_to_use_direct_io = 8286257203, index_granularity_bytes = 5612678, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 87, 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 = 31944, primary_key_compress_block_size = 99765, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:52.795625 [ 6024 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t_optimize_level already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:20:54.119632 [ 3863 ] {7b49911b-6218-4a32-b9d8-682b0cd05547} executeQuery: Code: 36. DB::Exception: Connection pool cannot have zero size. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56666) (comment: 02479_mysql_connect_to_self.sql) (query 25, line 44) (in query: SELECT count() FROM mysql('127.0.0.1:9004', currentDatabase(), foo, 'default', '[HIDDEN]', SETTINGS connection_pool_size = 0)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:44: DB::createMySQLPoolWithFailover(String const&, std::vector, std::allocator>> const&, String const&, String const&, String const&, String const&, String const&, DB::MySQLSettings const&) @ 0x0000000030a8d4cb 6. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:26: DB::createMySQLPoolWithFailover(DB::StorageMySQL::Configuration const&, DB::MySQLSettings const&) @ 0x0000000030a8d34a 7. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:96: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000028521dc2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:54.127077 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Connection pool cannot have zero size. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:44: DB::createMySQLPoolWithFailover(String const&, std::vector, std::allocator>> const&, String const&, String const&, String const&, String const&, String const&, DB::MySQLSettings const&) @ 0x0000000030a8d4cb 6. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:26: DB::createMySQLPoolWithFailover(DB::StorageMySQL::Configuration const&, DB::MySQLSettings const&) @ 0x0000000030a8d34a 7. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:96: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000028521dc2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:20:57.040244 [ 4142 ] {6108a4ef-cf82-4557-bb55-4ca884a89d3e} executeQuery: Code: 306. DB::Exception: JSON is too deep for key 'skipped_field': While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60142) (comment: 03213_deep_json.sql) (query 1, line 1) (in query: -- The default limit works. SELECT * FROM format("JSONCompactEachRow", 'x UInt32, y UInt32', REPEAT('[1,1,', 100000)) SETTINGS input_format_json_compact_allow_variable_number_of_columns = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b5742b 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 2025.07.13 02:20:57.089060 [ 4142 ] {} TCPHandler: Code: 306. DB::Exception: JSON is too deep for key 'skipped_field': While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b5742b 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 2025.07.13 02:20:57.267336 [ 4477 ] {ac4088b0-8c03-4d95-b1f3-c8f057e684e9} executeQuery: Code: 10. DB::Exception: Not found column key2 in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59748) (comment: 01881_join_on_conditions_hash.gen.sql) (query 25, line 31) (in query: SELECT t1.key FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND 0 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002cb2a0de 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1722: _ZZN2DB12_GLOBAL__N_131buildQueryPlanForJoinNodeLegacyERKNSt3__110shared_ptrINS_14IQueryTreeNodeEEENS_17JoinTreeQueryPlanES7_RKNS1_13unordered_setINS1_12basic_stringIcNS1_11char_traitsIcEENS1_9allocatorIcEEEENS1_4hashISE_EENS1_8equal_toISE_EENSC_ISE_EEEERNS2_INS_14PlannerContextEEERKNS_15SelectQueryInfoEENK3$_1clINS1_6vectorIPKNS_10ActionsDAG4NodeENSC_ISZ_EEEEEEDaRSW_RNS_9QueryPlanERNS8_INS2_INS_9FutureSetEEENSF_IS16_EENSH_IS16_EENSC_IS16_EEEERKT_ @ 0x000000002ddb9793 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1734: 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&) @ 0x000000002ddb54fc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:57.279538 [ 4477 ] {} TCPHandler: Code: 10. DB::Exception: Not found column key2 in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002cb2a0de 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1722: _ZZN2DB12_GLOBAL__N_131buildQueryPlanForJoinNodeLegacyERKNSt3__110shared_ptrINS_14IQueryTreeNodeEEENS_17JoinTreeQueryPlanES7_RKNS1_13unordered_setINS1_12basic_stringIcNS1_11char_traitsIcEENS1_9allocatorIcEEEENS1_4hashISE_EENS1_8equal_toISE_EENSC_ISE_EEEERNS2_INS_14PlannerContextEEERKNS_15SelectQueryInfoEENK3$_1clINS1_6vectorIPKNS_10ActionsDAG4NodeENSC_ISZ_EEEEEEDaRSW_RNS_9QueryPlanERNS8_INS2_INS_9FutureSetEEENSF_IS16_EENSH_IS16_EENSC_IS16_EEEERKT_ @ 0x000000002ddb9793 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1734: 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&) @ 0x000000002ddb54fc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:20:57.291986 [ 4142 ] {6be58d86-b249-4334-8d62-9e65ec30eb90} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f99c4b64000, frame address: 0x7f99c4f1ca30, stack size: 4486608, maximum stack size: 8388608: While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60142) (comment: 03213_deep_json.sql) (query 3, line 5) (in query: SELECT * FROM format("JSONCompactEachRow", 'x UInt32, y UInt32', REPEAT('[1,1,', 100000)) SETTINGS input_format_json_compact_allow_variable_number_of_columns = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./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&) @ 0x0000000023b1752f 5. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x0000000023b17388 6. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57446 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 2025.07.13 02:20:57.297652 [ 4142 ] {} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f99c4b64000, frame address: 0x7f99c4f1ca30, stack size: 4486608, maximum stack size: 8388608: While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./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&) @ 0x0000000023b1752f 5. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x0000000023b17388 6. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57446 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57856 2025.07.13 02:20:57.571106 [ 6951 ] {deb59bcb-1321-4562-86f4-1692b2fd989b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `xyz` in scope SELECT xyz. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60160) (comment: 00380_client_break_at_exception_in_batch_mode.sh) (query 2, line 1) (in query: SELECT xyz;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:57.627891 [ 6951 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `xyz` in scope SELECT xyz. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:58.728117 [ 4142 ] {ebeec60d-f842-4ce6-be43-abd7b0f3ec66} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60232) (comment: 02400_memory_accounting_on_error.sql) (query 1, line 1) (in query: -- max_block_size to avoid randomization SELECT * FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536 SETTINGS max_memory_usage='1Gi', max_block_size=65505, log_queries=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030423da3 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030426d69 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042eebc 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:20:58.740957 [ 4142 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030423da3 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030426d69 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042eebc 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.127274 [ 5380 ] {} TCPHandler: Code: 702. DB::Exception: Client info's client_name does not match: ClickHouse client not equal to Hacker client. (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Server/TCPHandler.cpp:219: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c8c88 6. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 7. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.164701 [ 3766 ] {2e3dc730-3f0f-4985-84b6-1b60ed93c2f3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56844) (comment: 01010_pmj_skip_blocks.sql) (query 41, line 49) (in query: SELECT t1.*, t2.x FROM t1 ANY INNER JOIN t2 USING (x,y) ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.172322 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.268726 [ 5380 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 58. Bytes expected: 83. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/Server/TCPHandler.cpp:1829: DB::TCPHandler::processUnexpectedHello() @ 0x00000000316c6498 7. ./build_docker/./src/Server/TCPHandler.cpp:891: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8f8 8. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.270209 [ 5732 ] {} TCPHandler: Code: 702. DB::Exception: Client info's version does not match: 20.13.0 (54443) not equal to 16.13.1 (54443). (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Server/TCPHandler.cpp:227: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316ccaae 6. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 7. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.272123 [ 5732 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 58. Bytes expected: 83. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/Server/TCPHandler.cpp:1829: DB::TCPHandler::processUnexpectedHello() @ 0x00000000316c6498 7. ./build_docker/./src/Server/TCPHandler.cpp:891: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8f8 8. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.883991 [ 7056 ] {279f3f95-3634-4bfb-bf0d-8850395ce869} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, UInt8) to AggregateFunction(sum, Int32) is not supported: while converting source column pv to destination column pv. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53114) (comment: 01880_materialized_view_to_table_type_check.sql) (query 6, line 9) (in query: CREATE MATERIALIZED VIEW test_mv to test(`id` Int32, `pv` AggregateFunction(sum, Int32)) as SELECT id, sumState(1) as pv from test_input group by id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb1a59c 12. ./build_docker/./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>>*) @ 0x000000002cb2ce07 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1151: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc76c5a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:20:59.908910 [ 7056 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, UInt8) to AggregateFunction(sum, Int32) is not supported: while converting source column pv to destination column pv. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb1a59c 12. ./build_docker/./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>>*) @ 0x000000002cb2ce07 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1151: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc76c5a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:21:00.814690 [ 2824 ] {1ad58dff-11c4-4a76-adb8-80d8d4755532} OptimizeRegularExpression: Analyze RegularExpression failed, got error: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f9b7df1b000, frame address: 0x7f9b7e31af20, stack size: 4194528, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:00.918137 [ 2824 ] {1ad58dff-11c4-4a76-adb8-80d8d4755532} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53170) (comment: 02831_regexp_analyze_recursion.sql) (query 1, line 1) (in query: SELECT match('', repeat('(', 100000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001dce36f8 7. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcddf44 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:00.928693 [ 2824 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001dce36f8 7. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcddf44 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:01.054799 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:01.112618 [ 2825 ] {16ef2fe6-deea-4194-ace7-c2348812cda8} 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.3.20372.altinityantalya (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53194) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:146: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852fc79 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:01.125495 [ 2825 ] {} 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.3.20372.altinityantalya (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:146: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852fc79 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:01.806743 [ 3863 ] {f3fb8d61-73b4-4d9e-8e6d-65e2f4bd526c} executeQuery: Code: 36. DB::Exception: Connection pool cannot have zero size. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56666) (comment: 02479_mysql_connect_to_self.sql) (query 45, line 78) (in query: SELECT count() FROM mysql('[::1]:9004', currentDatabase(), foo, 'default', '[HIDDEN]', SETTINGS connection_pool_size = 0)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:44: DB::createMySQLPoolWithFailover(String const&, std::vector, std::allocator>> const&, String const&, String const&, String const&, String const&, String const&, DB::MySQLSettings const&) @ 0x0000000030a8d4cb 6. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:26: DB::createMySQLPoolWithFailover(DB::StorageMySQL::Configuration const&, DB::MySQLSettings const&) @ 0x0000000030a8d34a 7. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:96: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000028521dc2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:21:01.830908 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Connection pool cannot have zero size. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:44: DB::createMySQLPoolWithFailover(String const&, std::vector, std::allocator>> const&, String const&, String const&, String const&, String const&, String const&, DB::MySQLSettings const&) @ 0x0000000030a8d4cb 6. ./build_docker/./src/Storages/MySQL/MySQLHelpers.cpp:26: DB::createMySQLPoolWithFailover(DB::StorageMySQL::Configuration const&, DB::MySQLSettings const&) @ 0x0000000030a8d34a 7. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:96: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000028521dc2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:21:02.533960 [ 4142 ] {2eee4c90-6c15-4e0a-a53f-9772acc42e06} executeQuery: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53304) (comment: 01732_union_and_union_all.sql) (query 1, line 1) (in query: select 1 UNION select 1 UNION ALL select 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002deda3d1 6. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:36: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002ded8a03 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002c75ae82 8. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2aa501 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:02.540907 [ 4142 ] {} TCPHandler: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002deda3d1 6. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:36: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002ded8a03 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002c75ae82 8. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2aa501 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.013225 [ 3885 ] {4dce84d5-bcc8-448f-a232-8ff42f38bd14} executeQuery: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53402) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 1, line 2) (in query: CREATE TABLE t ( 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.023180 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.177009 [ 4477 ] {c603afc6-2403-48ad-95c8-317f0b71fcea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59748) (comment: 01881_join_on_conditions_hash.gen.sql) (query 46, line 56) (in query: SELECT DISTINCT t1.id FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND toNullable(toLowCardinality(t1.key2 != ''));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.198822 [ 4477 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.649406 [ 4938 ] {69bd162e-e5f5-4f0a-b702-fbd13c5a0d1d} executeQuery: Code: 344. DB::Exception: Partition operation ALTER TABLE ATTACH PARTITION is not supported for immutable disk '03008_alter_partition'. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53484) (comment: 03008_s3_plain_rewritable_alter_partition.sh) (query 1, line 1) (in query: ALTER TABLE 03008_alter_partition ATTACH PARTITION 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030d06b3b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4ce7f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.680596 [ 4938 ] {} TCPHandler: Code: 344. DB::Exception: Partition operation ALTER TABLE ATTACH PARTITION is not supported for immutable disk '03008_alter_partition'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030d06b3b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4ce7f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.680650 [ 5480 ] {e07ffc6c-2683-4bf4-8338-9faf89285f60} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53440) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:03.688084 [ 5480 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.176525 [ 4477 ] {064ed8a8-e98f-4766-9150-f3e0f1a76818} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53528) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.212055 [ 4477 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.460630 [ 6951 ] {ee5b5685-2dbc-448c-9cf2-0e62f0e749bc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53468) (comment: 03221_insert_timeout_overflow_mode.sh) (query 1, line 1) (in query: insert into null_t format Native), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:88: DB::throwOnExecutionStatus(DB::PipelineExecutor::ExecutionStatus) @ 0x00000000318449a0 6. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:115: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000031844c02 7. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:120: DB::PushingPipelineExecutor::push(DB::Block) @ 0x0000000031844c85 8. ./build_docker/./src/Server/TCPHandler.cpp:1121: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0c90 9. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.701548 [ 6951 ] {ee5b5685-2dbc-448c-9cf2-0e62f0e749bc} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 32. DB::Exception: Attempt to read after eof. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x0000000023b6680e 6. ./src/IO/VarInt.h:78: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x00000000316ce9cb 7. ./build_docker/./src/Server/TCPHandler.cpp:1031: DB::TCPHandler::skipData(DB::QueryState&) @ 0x00000000316c39fb 8. ./build_docker/./src/Server/TCPHandler.cpp:830: DB::TCPHandler::runImpl() @ 0x00000000316add8e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:04.708622 [ 6951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:88: DB::throwOnExecutionStatus(DB::PipelineExecutor::ExecutionStatus) @ 0x00000000318449a0 6. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:115: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000031844c02 7. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:120: DB::PushingPipelineExecutor::push(DB::Block) @ 0x0000000031844c85 8. ./build_docker/./src/Server/TCPHandler.cpp:1121: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0c90 9. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.763112 [ 5382 ] {1f78b5b9-a2ae-4ce8-b754-8c7b8966d667} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53596) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.794559 [ 5382 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.878926 [ 3885 ] {23fae344-b2c1-4d34-927a-76fdedbb8954} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53458) (comment: 03221_insert_timeout_overflow_mode.sh) (query 1, line 1) (in query: select sleep(0.1) from system.numbers settings max_block_size = 1 format Native), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f9d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:21:04.885382 [ 3885 ] {23fae344-b2c1-4d34-927a-76fdedbb8954} 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]:53458). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:04.887176 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f9d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:21:05.427619 [ 4477 ] {3f81fa97-28c0-4484-acdf-01847da8c4fc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53632) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:05.463565 [ 4477 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:06.008717 [ 4477 ] {ce473614-c95b-448f-90d9-777287682f38} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53670) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:06.029048 [ 4477 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:06.499311 [ 4142 ] {44e21a8f-e806-45ab-919f-a4b8298763b7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53698) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:06.517764 [ 4142 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:07.080702 [ 4938 ] {f8d59de3-def8-4d8d-9cfc-dff71b912d98} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53706) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:07.114229 [ 4938 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:07.641600 [ 3449 ] {a8813bff-9b4b-4979-8583-772f3f08f217::all_1_19_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:07.659414 [ 4938 ] {917cd3ac-ef93-4e73-bdef-bf85e032dbcd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53724) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:07.727418 [ 4938 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:08.298675 [ 4938 ] {c5a685d0-b78b-4c27-8541-1a7d74c8933e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53742) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:08.321565 [ 4938 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:08.692862 [ 5380 ] {290acd5e-1efe-4b68-a9a9-5db42b6cff92} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38948) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x0000000031b5e69e 10. ./src/Processors/Formats/IOutputFormat.h:120: DB::IOutputFormat::writeSuffixIfNeeded() @ 0x000000003184d4b7 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:164: DB::IOutputFormat::finalizeUnlocked() @ 0x000000003184bfa6 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:89: DB::IOutputFormat::work() @ 0x000000003184b291 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:08.696686 [ 5380 ] {290acd5e-1efe-4b68-a9a9-5db42b6cff92} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x0000000031b5e69e 10. ./src/Processors/Formats/IOutputFormat.h:120: DB::IOutputFormat::writeSuffixIfNeeded() @ 0x000000003184d4b7 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:164: DB::IOutputFormat::finalizeUnlocked() @ 0x000000003184bfa6 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:89: DB::IOutputFormat::work() @ 0x000000003184b291 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:08.883807 [ 4938 ] {db060868-d098-44e4-a7f4-f4fe4c9e5219} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53752) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:09.000919 [ 4938 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:09.399806 [ 3863 ] {7fb3183c-8895-4ae3-a6ea-ca14886e2653} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36302) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:09.424540 [ 3863 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:09.850427 [ 3863 ] {46dda102-c2f0-4658-8364-616ca356afed} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36306) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:09.872869 [ 3863 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:10.325334 [ 3863 ] {b676eebb-d03f-491f-a0ef-b3e202c305d7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36330) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:10.356061 [ 3863 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:10.730868 [ 3863 ] {d9b35dbd-ff6f-4fa1-b650-df475df0aa67} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36356) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:10.839580 [ 3863 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:11.437770 [ 3863 ] {3e181d49-dc03-4c0b-865d-ebab2560a9f4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36364) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:11.454213 [ 3863 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:11.937294 [ 5380 ] {b0590afb-76b1-424d-b5c4-fba3a7501641} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36378) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:11.951252 [ 5380 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:12.503444 [ 5380 ] {f4960bc3-e3f6-4fbc-8ae6-8390de61cba9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36406) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:12.529045 [ 5380 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:12.896836 [ 5380 ] {e4622723-6afc-43ba-8092-1bc24735dea8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36426) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:12.914803 [ 5380 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:13.577354 [ 3863 ] {d99766af-ef69-424c-8f06-deb80b188c5c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36436) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:13.583750 [ 3863 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:14.002303 [ 5380 ] {f82424ba-1f77-479c-a406-fc5d33d09abd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36462) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:14.017149 [ 5380 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t GROUP BY item_id. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:14.432701 [ 3815 ] {9fccb20d-115f-49b6-a15b-9855ca7892ca} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36500) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:14.472308 [ 3815 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:15.014936 [ 4142 ] {463d710c-8715-408b-8c59-36d0d9f6fa2b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36502) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:15.043760 [ 4142 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:15.270910 [ 3815 ] {1e714146-06ed-4961-8ca4-58bce76829da} executeQuery: Code: 36. DB::Exception: Could not decode the provided hash with 'bcrypt_hash'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36530) (comment: 03172_bcrypt_validation.sql) (query 2, line 3) (in query: CREATE USER `03172_user_invalid_bcrypt_hash` IDENTIFIED WITH bcrypt_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Access/AuthenticationData.cpp:250: DB::AuthenticationData::setPasswordHashBinary(std::vector> const&, bool) @ 0x000000002be0509a 6. ./build_docker/./src/Access/AuthenticationData.cpp:530: DB::AuthenticationData::fromAST(DB::ASTAuthenticationData const&, std::shared_ptr, bool) @ 0x000000002be08102 7. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:211: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f977883 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:15.273964 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Could not decode the provided hash with 'bcrypt_hash'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Access/AuthenticationData.cpp:250: DB::AuthenticationData::setPasswordHashBinary(std::vector> const&, bool) @ 0x000000002be0509a 6. ./build_docker/./src/Access/AuthenticationData.cpp:530: DB::AuthenticationData::fromAST(DB::ASTAuthenticationData const&, std::shared_ptr, bool) @ 0x000000002be08102 7. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:211: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f977883 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:15.509889 [ 7056 ] {561ac793-bc65-48dd-9427-662fee6d9c43} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36574) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:15.526592 [ 7056 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.018923 [ 5480 ] {7db6951c-098e-4e14-aac0-e488ea1ea687} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36640) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.036452 [ 5480 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `item_id` in scope SELECT item_id, price_sold FROM t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5135: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e31b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.339513 [ 3863 ] {733ef079-5fd2-419c-9699-2d044b392dd8} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36572) (comment: 02465_limit_trivial_max_rows_to_read.sql) (query 7, line 13) (in query: SELECT number FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x00000000322574d4 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000032255477 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032253779 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.352549 [ 3863 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x00000000322574d4 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000032255477 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032253779 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.463189 [ 3863 ] {25f60c94-43a9-45dc-8557-2cfacc1e27f0} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36572) (comment: 02465_limit_trivial_max_rows_to_read.sql) (query 8, line 14) (in query: SELECT number FROM numbers(30) LIMIT 21;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x00000000322574d4 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000032255477 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032253779 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.475517 [ 3863 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x00000000322574d4 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000032255477 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032253779 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.920498 [ 3815 ] {d149b66f-6519-45ae-bdc9-a9f2e5d3de5b} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36598) (comment: 03326_parallel_replicas_out_of_range.sql) (query 3, line 8) (in query: SELECT count(materialize(toLowCardinality(1))) IGNORE NULLS AS num, hostName() AS hostName FROM system.query_log AS a INNER JOIN system.processes AS b ON (type = toFixedString(toNullable('QueryStart'), 10)) AND (dateDiff('second', event_time, now()) > 5) AND (current_database = currentDatabase()) FORMAT `Null`;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff37d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 13. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 16. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 17. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:21:16.940446 [ 3815 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff37d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 13. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 16. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 17. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:21:17.208607 [ 3863 ] {712d6489-38d3-4e1d-8150-04b7fb872f37} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36572) (comment: 02465_limit_trivial_max_rows_to_read.sql) (query 12, line 19) (in query: SELECT a FROM t_max_rows_to_read LIMIT 11 offset 11;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:17.219571 [ 3863 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:17.279720 [ 3863 ] {f5acfb11-7ed1-4363-9839-066b9569fd79} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 52.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36572) (comment: 02465_limit_trivial_max_rows_to_read.sql) (query 13, line 20) (in query: SELECT a FROM t_max_rows_to_read WHERE a > 50 LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:17.294473 [ 3863 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 52.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:18.769461 [ 6024 ] {601ab28c-db99-4eec-87e4-2921fb4a6225} executeQuery: Code: 131. DB::Exception: Too many times to repeat (1000001), maximum is: 1000000: In scope SELECT length(repeat('x', 1000001)). (TOO_LARGE_STRING_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36730) (comment: 01014_function_repeat_corner_cases.sql) (query 3, line 3) (in query: SELECT length(repeat('x', 1000001));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. DB::(anonymous namespace)::RepeatImpl::checkRepeatTime(unsigned long) @ 0x0000000020705099 6. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda0'(auto const&)::operator()>(auto const&) const @ 0x000000002070a95d 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_IN4wide7integerILm128EiEEEENS1_INS8_ILm256EiEEEENS1_IDuEENS1_ItEENS1_IjEENS1_ImEENS1_INS8_ILm128EjEEEENS1_INS8_ILm256EjEEEEENS_9IDataTypeEZNKS_12_GLOBAL__N_114FunctionRepeat11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENSO_9allocatorISQ_EEEERKNSO_10shared_ptrIKSL_EEmEUlRKT_E0_EEbPKT0_OT1_ @ 0x0000000020706eb1 8. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206fca7f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:21:18.784666 [ 6024 ] {} TCPHandler: Code: 131. DB::Exception: Too many times to repeat (1000001), maximum is: 1000000: In scope SELECT length(repeat('x', 1000001)). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. DB::(anonymous namespace)::RepeatImpl::checkRepeatTime(unsigned long) @ 0x0000000020705099 6. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda0'(auto const&)::operator()>(auto const&) const @ 0x000000002070a95d 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_IN4wide7integerILm128EiEEEENS1_INS8_ILm256EiEEEENS1_IDuEENS1_ItEENS1_IjEENS1_ImEENS1_INS8_ILm128EjEEEENS1_INS8_ILm256EjEEEEENS_9IDataTypeEZNKS_12_GLOBAL__N_114FunctionRepeat11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENSO_9allocatorISQ_EEEERKNSO_10shared_ptrIKSL_EEmEUlRKT_E0_EEbPKT0_OT1_ @ 0x0000000020706eb1 8. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206fca7f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:21:19.105952 [ 6024 ] {5931755b-5c67-40f6-97da-49845d1be6bd} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 144.07 MiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 95.37 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36730) (comment: 01014_function_repeat_corner_cases.sql) (query 5, line 5) (in query: SELECT length(repeat(repeat('Hello, world!', 1000000), 10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda0'(auto const&)::operator()>(auto const&) const @ 0x0000000020709449 12. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_IN4wide7integerILm128EiEEEENS1_INS8_ILm256EiEEEENS1_IDuEENS1_ItEENS1_IjEENS1_ImEENS1_INS8_ILm128EjEEEENS1_INS8_ILm256EjEEEEENS_9IDataTypeEZNKS_12_GLOBAL__N_114FunctionRepeat11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENSO_9allocatorISQ_EEEERKNSO_10shared_ptrIKSL_EEmEUlRKT_E0_EEbPKT0_OT1_ @ 0x0000000020706e31 13. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206fca7f 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb194ab 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x000000002cb1a20a 23. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb86a70 24. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1005: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb84ded 25. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7bd4c 26. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb99f84 27. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002de09817 28. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a4fb 29. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 2025.07.13 02:21:19.116711 [ 6024 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 144.07 MiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 95.37 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda0'(auto const&)::operator()>(auto const&) const @ 0x0000000020709449 12. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_IN4wide7integerILm128EiEEEENS1_INS8_ILm256EiEEEENS1_IDuEENS1_ItEENS1_IjEENS1_ImEENS1_INS8_ILm128EjEEEENS1_INS8_ILm256EjEEEEENS_9IDataTypeEZNKS_12_GLOBAL__N_114FunctionRepeat11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENSO_9allocatorISQ_EEEERKNSO_10shared_ptrIKSL_EEmEUlRKT_E0_EEbPKT0_OT1_ @ 0x0000000020706e31 13. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206fca7f 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb194ab 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x000000002cb1a20a 23. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb86a70 24. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1005: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb84ded 25. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7bd4c 26. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb99f84 27. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002de09817 28. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a4fb 29. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 2025.07.13 02:21:19.660086 [ 4938 ] {321d0b87-5ce3-49b8-869a-473e99f89075} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36542) (comment: 02421_decimal_in_precision_issue_41125.sql) (query 19, line 28) (in query: SELECT count() == 0 FROM dtest WHERE a IN toDecimal32('33.3000', 4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:19.672379 [ 4938 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:21.120788 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:23.185266 [ 6951 ] {73229ad2-338d-40b8-b2b9-8cec43d27e3b} executeQuery: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 37, line 50) (in query: -- { echoOff } SELECT sparkbar(0)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d6e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.200650 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d6e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.349248 [ 6951 ] {56f5fa39-e288-4fa5-93b1-40ca8416c044} executeQuery: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 38, line 53) (in query: SELECT sparkbar(1)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d6e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.381099 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d6e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.509081 [ 6951 ] {c2a20d8b-b945-4f19-b704-6960f84bcd75} executeQuery: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 39, line 54) (in query: SELECT sparkbar(1025)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d6e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.536300 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Parameter width must be in range [2, 1024]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d6e0 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.681187 [ 6951 ] {4abbd131-872e-447e-ae54-67ee4ddb8e63} executeQuery: Code: 36. DB::Exception: Parameter `min_x` must be less than `max_x`. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 40, line 55) (in query: SELECT sparkbar(2, 10, 9)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:285: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6cb59 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.685850 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Parameter `min_x` must be less than `max_x`. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:285: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6cb59 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.817839 [ 6951 ] {77a578a7-12ee-4153-860e-40e838bcf9c3} executeQuery: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 41, line 56) (in query: SELECT sparkbar(2, -5, -1)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f649e1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:23.882986 [ 6951 ] {} TCPHandler: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f649e1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.049364 [ 6951 ] {b5a29d90-a411-4158-8d8d-1bee4d9b278c} executeQuery: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 42, line 57) (in query: SELECT sparkbar(2, -5, 1)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f649e1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.082490 [ 6951 ] {} TCPHandler: Code: 43. DB::Exception: The second and third parameters are not the same type as the first arguments for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f649e1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.213917 [ 6951 ] {b4b65d9d-31e0-4175-9199-d93082c767a5} executeQuery: Code: 43. DB::Exception: The first argument type must be UInt or Date or DateTime for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 43, line 58) (in query: SELECT sparkbar(2)(toInt32(number), number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:339: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d3bd 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.229236 [ 6951 ] {} TCPHandler: Code: 43. DB::Exception: The first argument type must be UInt or Date or DateTime for aggregate function sparkbar. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:339: DB::IAggregateFunction* DB::(anonymous namespace)::createWithUIntegerOrTimeType, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, std::vector, std::allocator>>&&, DB::Array&&) @ 0x0000000027f6d3bd 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:349: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f6465d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.348422 [ 6951 ] {8c5dbe65-318d-438e-8223-9a5ba7f0f623} executeQuery: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 44, line 59) (in query: SELECT sparkbar(2, 0)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x0000000018d3bdef 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f648fd 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.357758 [ 6951 ] {} TCPHandler: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x0000000018d3bdef 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f648fd 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.442698 [ 6951 ] {0872f04c-5889-415d-9e60-d7c405b08ef2} executeQuery: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 4. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36512) (comment: 02016_aggregation_spark_bar.sql) (query 45, line 60) (in query: SELECT sparkbar(2, 0, 5, 8)(number, number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x0000000018d3bdef 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f648fd 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:24.453892 [ 6951 ] {} TCPHandler: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 4. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x0000000018d3bdef 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027f648fd 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:21:25.444443 [ 3863 ] {8b258cbe-63dc-4abf-b1a1-6ba81f6c4d92} executeQuery: Code: 128. DB::Exception: Too large array size: 9223372036854775808, maximum: 1073741824: In scope SELECT arrayResize([1, 2, 3], -9223372036854775808). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47072) (comment: 01682_gather_utils_ubsan.sql) (query 1, line 1) (in query: SELECT arrayResize([1, 2, 3], -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. void DB::GatherUtils::resizeDynamicSize&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&>(DB::GatherUtils::NumericArraySource&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&, DB::IColumn const&) @ 0x000000002d3e9fbf 6. DB::GatherUtils::resizeDynamicSize(DB::GatherUtils::IArraySource&, DB::GatherUtils::IValueSource&, DB::GatherUtils::IArraySink&, DB::IColumn const&) @ 0x000000002d2a1760 7. ./build_docker/./src/Functions/array/arrayResize.cpp:113: DB::FunctionArrayResize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d17a7d0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:25.449303 [ 3863 ] {} TCPHandler: Code: 128. DB::Exception: Too large array size: 9223372036854775808, maximum: 1073741824: In scope SELECT arrayResize([1, 2, 3], -9223372036854775808). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. void DB::GatherUtils::resizeDynamicSize&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&>(DB::GatherUtils::NumericArraySource&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&, DB::IColumn const&) @ 0x000000002d3e9fbf 6. DB::GatherUtils::resizeDynamicSize(DB::GatherUtils::IArraySource&, DB::GatherUtils::IValueSource&, DB::GatherUtils::IArraySink&, DB::IColumn const&) @ 0x000000002d2a1760 7. ./build_docker/./src/Functions/array/arrayResize.cpp:113: DB::FunctionArrayResize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d17a7d0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:27.379688 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:27.386895 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:21:27.390567 [ 3863 ] {52703b47-12aa-4488-9566-ed8c7de8ce5a} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47128) (comment: 00973_create_table_as_table_function.sql) (query 6, line 7) (in query: SELECT count() FROM t1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:21:27.420141 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:28.549949 [ 3461 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {63667ff6-b6f5-414a-9058-bdd20928b151::202507_1_41_8}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:29.245547 [ 3766 ] {529d7736-09e4-495d-9b8f-848920540c24} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47280) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 3500000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x0000000031b59683 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::finalizeUnlocked() @ 0x000000003184bfbb 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:89: DB::IOutputFormat::work() @ 0x000000003184b291 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:21:29.252372 [ 3766 ] {529d7736-09e4-495d-9b8f-848920540c24} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x0000000031b59683 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::finalizeUnlocked() @ 0x000000003184bfbb 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:89: DB::IOutputFormat::work() @ 0x000000003184b291 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:29.308771 [ 3885 ] {b197c12f-fd6a-472d-b49f-a83e6874e34f} executeQuery: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:51910) (comment: 02009_from_infile.sh) (in query: INSERT INTO test_infile_url FROM INFILE '/repo/tests/queries/0_stateless/test_infile.gz' FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000031f16b60 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcef996 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:21:29.313757 [ 3885 ] {b197c12f-fd6a-472d-b49f-a83e6874e34f} DynamicQueryHandler: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000031f16b60 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcef996 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:29.598180 [ 3885 ] {702bab61-d4bb-41cb-a702-1679cfad593f} executeQuery: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58560) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:29.605976 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:30.316591 [ 5380 ] {02aa331f-e82f-4b59-bd23-1a4b9426470c} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (36a067b7-7a66-4af7-a4b8-d86b7b02b306) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58618) (comment: 00952_basic_constraints.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:30.341310 [ 5380 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (36a067b7-7a66-4af7-a4b8-d86b7b02b306) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.460880 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.463323 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.555298 [ 5382 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52766). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:422: DB::TCPHandler::runImpl() @ 0x00000000316b3019 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:33.555565 [ 6024 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:33062). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:422: DB::TCPHandler::runImpl() @ 0x00000000316b3019 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:33.556091 [ 5382 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52766, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:33.556496 [ 6024 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33062, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:33.556718 [ 5382 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52766, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:33.558323 [ 6024 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33062, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:33.561040 [ 4938 ] {55e9348e-0957-4fd8-8e7a-41566c7961cb} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58702) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:21:33.578806 [ 4938 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.595422 [ 5379 ] {48c607e1-4b08-46fe-a8b1-f5e74c7c87e4} executeQuery: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58718) (comment: 01474_bad_global_join.sql) (query 6, line 13) (in query: SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5272: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61039 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.595620 [ 5380 ] {6d3c784a-7129-4b93-bce5-d8b257b1e71f} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (d44b44a4-f3fd-4d0a-9369-43114a0495df) is violated at row 1. Expression: (b > 10). Column values: b = 2. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58746) (comment: 00952_basic_constraints.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.600149 [ 5379 ] {} TCPHandler: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x000000002cc6716f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5272: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61039 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:21:33.601064 [ 5380 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (d44b44a4-f3fd-4d0a-9369-43114a0495df) is violated at row 1. Expression: (b > 10). Column values: b = 2. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:34.290971 [ 2824 ] {fc5b1021-f171-44ad-bf31-7c27b13c1c2c} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46878) (comment: 00930_max_partitions_per_insert_block.sql) (query 9, line 12) (in query: INSERT INTO partitions SELECT * FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000030e4870b 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234b61 7. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:34.317841 [ 2824 ] {} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000030e4870b 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234b61 7. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:21:34.568872 [ 4142 ] {53ab9629-a164-44ba-87ac-c9d15daddca9} executeQuery: Code: 469. DB::Exception: Constraint `a_constraint` for table test_5.test_constraints (d44b44a4-f3fd-4d0a-9369-43114a0495df) is violated at row 2. Expression: (a < 10). Column values: a = 10. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58826) (comment: 00952_basic_constraints.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:34.576205 [ 4142 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `a_constraint` for table test_5.test_constraints (d44b44a4-f3fd-4d0a-9369-43114a0495df) is violated at row 2. Expression: (a < 10). Column values: a = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:34.668785 [ 6913 ] {} test_13.partitions (43610344-2d2c-4487-820e-3f7d1bd82c06): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:21:34.924586 [ 6913 ] {} DatabaseCatalog: Cannot drop table test_13.partitions (43610344-2d2c-4487-820e-3f7d1bd82c06). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:37.675980 [ 6951 ] {4f0a275a-f28b-4694-8c8c-cc720bbc2deb} executeQuery: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58816) (comment: 00933_alter_ttl.sql) (query 12, line 16) (in query: alter table ttl modify ttl a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c068 6. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082d386 7. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c7948 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:37.684665 [ 6951 ] {} TCPHandler: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c068 6. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082d386 7. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c7948 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:38.558753 [ 6951 ] {3622ab7e-6506-4b7f-a7cd-a87ae8d8ab3c} executeQuery: Code: 43. DB::Exception: Illegal type Int32 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: While processing toDayOfMonth(d). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58816) (comment: 00933_alter_ttl.sql) (query 17, line 23) (in query: alter table ttl modify column d Int ttl d + interval 1 day;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x0000000020a87707 6. DB::FunctionDateOrDateTimeToSomething, DB::ToDayOfMonthImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ab63c6 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb184e3 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 11. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 17. ./build_docker/./src/Storages/KeyDescription.cpp:165: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033a904 18. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003033a0cf 19. ./build_docker/./src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0f08 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:38.563678 [ 6951 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int32 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: While processing toDayOfMonth(d). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x0000000020a87707 6. DB::FunctionDateOrDateTimeToSomething, DB::ToDayOfMonthImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ab63c6 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb184e3 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 11. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 17. ./build_docker/./src/Storages/KeyDescription.cpp:165: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033a904 18. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003033a0cf 19. ./build_docker/./src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0f08 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:38.818802 [ 6951 ] {26b519cb-4327-472d-a63a-8c677be6a43a} executeQuery: Code: 524. DB::Exception: ALTER of key column d is forbidden. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58816) (comment: 00933_alter_ttl.sql) (query 18, line 24) (in query: alter table ttl modify column d DateTime ttl d + interval 1 day;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3797: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd66ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:38.862882 [ 6951 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of key column d is forbidden. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3797: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd66ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:38.902374 [ 3885 ] {9f32950d-b1a0-4d61-8e24-c9800b166a1c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48990) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:38.907235 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.004549 [ 10341 ] {a53362b0-2bd1-4a99-a1e8-df6074d47945} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 0 arguments: In scope SELECT compareSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 1, line 1) (in query: -- Negative tests -- Five arguments are expected select compareSubstrings();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.016187 [ 10341 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 0 arguments: In scope SELECT compareSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.215838 [ 10341 ] {214499e3-d15a-4421-aa7a-91e36f5bea10} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 1 argument: In scope SELECT compareSubstrings('abc'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 2, line 5) (in query: select compareSubstrings('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.220726 [ 10341 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 1 argument: In scope SELECT compareSubstrings('abc'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.280593 [ 10341 ] {7090eff0-53fa-4aa4-afee-f5fe2d0b9408} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 2 arguments: In scope SELECT compareSubstrings('abc', 'abc'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 3, line 6) (in query: select compareSubstrings('abc', 'abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.283196 [ 10341 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 2 arguments: In scope SELECT compareSubstrings('abc', 'abc'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.335989 [ 10341 ] {b599dff5-8c45-4d00-8dca-d89e2d0de19f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 3 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 4, line 7) (in query: select compareSubstrings('abc', 'abc', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.348076 [ 10341 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 3 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.627727 [ 10341 ] {752f73de-bdcd-4650-a13f-52c811c59dae} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 4 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0, 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 5, line 8) (in query: select compareSubstrings('abc', 'abc', 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.630265 [ 10341 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 4 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0, 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.660563 [ 10341 ] {75c97608-3310-420b-88df-a0307247b8d8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 6 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, 0, 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 6, line 9) (in query: select compareSubstrings('abc', 'abc', 0, 0, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.671189 [ 10341 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 6 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, 0, 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.758112 [ 6024 ] {1c932a2c-b92d-469f-bcf1-35cc1508529c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58776) (comment: 02131_row_policies_combination.sql) (query 34, line 54) (in query: SELECT * FROM 02131_rptable;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:21:39.808833 [ 6024 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:40.002951 [ 10341 ] {a6ef2183-ade8-4a5c-b639-9b5dfe4dfed2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string1' to function 'compareSubstrings'. Expected: String, got: UInt8: In scope SELECT compareSubstrings(0, 'abc', 0, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 7, line 11) (in query: -- 1st/2nd argument must be string, 3rd/4th/5th argument must be integer select compareSubstrings(0, 'abc', 0, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.014035 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string1' to function 'compareSubstrings'. Expected: String, got: UInt8: In scope SELECT compareSubstrings(0, 'abc', 0, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.095647 [ 10341 ] {6f855fe3-53de-404a-a350-08843c43eed2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'string2' to function 'compareSubstrings'. Expected: String, got: UInt8: In scope SELECT compareSubstrings('abc', 0, 0, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 8, line 13) (in query: select compareSubstrings('abc', 0, 0, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.100176 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'string2' to function 'compareSubstrings'. Expected: String, got: UInt8: In scope SELECT compareSubstrings('abc', 0, 0, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.165290 [ 10341 ] {587b12dc-8464-42b9-9b7f-d8031475b30f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'string1_offset' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 'abc', 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 9, line 14) (in query: select compareSubstrings('abc', 'abc', 'abc', 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.174698 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'string1_offset' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 'abc', 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.208135 [ 3885 ] {d39d8fcd-dc71-4a78-a5e4-4dceb19ea5ee} executeQuery: Code: 141. DB::Exception: Illegal SAMPLE: table test_3.numbers1 (df20802c-2847-4985-a9ef-39023d9d89d3) doesn't support sampling: Child table: test_3.numbers1 (df20802c-2847-4985-a9ef-39023d9d89d3). (SAMPLING_NOT_SUPPORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49020) (comment: 00578_merge_table_sampling.sql) (query 5, line 7) (in query: SELECT * FROM merge(currentDatabase(), '^numbers\\d+$') SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageMerge.cpp:660: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000003051bedf 6. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000003051491d 7. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000003052a7c7 8. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228d4bc 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003228c797 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289cb2 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:40.217567 [ 3885 ] {} TCPHandler: Code: 141. DB::Exception: Illegal SAMPLE: table test_3.numbers1 (df20802c-2847-4985-a9ef-39023d9d89d3) doesn't support sampling: Child table: test_3.numbers1 (df20802c-2847-4985-a9ef-39023d9d89d3). (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageMerge.cpp:660: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000003051bedf 6. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000003051491d 7. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000003052a7c7 8. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228d4bc 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003228c797 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289cb2 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:40.295458 [ 10341 ] {5890481e-5b65-4987-bed2-8dd6fa0a8e33} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'string2_offset' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 0, 'abc', 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 10, line 15) (in query: select compareSubstrings('abc', 'abc', 0, 'abc', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.301288 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'string2_offset' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 0, 'abc', 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.369693 [ 10341 ] {bcaea021-5c05-4511-ba0c-9cf67871d318} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'num_bytes' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 11, line 16) (in query: select compareSubstrings('abc', 'abc', 0, 0, 'abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.377569 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'num_bytes' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.459606 [ 10341 ] {acbf050f-5081-4c87-af6d-fdee9974398c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'string1_offset' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', -1, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 12, line 18) (in query: -- 3rd, 4th, 5th argument must be non-negative select compareSubstrings('abc', 'abc', -1, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.471794 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'string1_offset' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', -1, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.618069 [ 10341 ] {b38ac1d2-ce69-46d0-9679-91d725893ad1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'string2_offset' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', 0, -1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 13, line 20) (in query: select compareSubstrings('abc', 'abc', 0, -1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.688405 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'string2_offset' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', 0, -1, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.719843 [ 10341 ] {21363920-34d7-4316-86d5-5a323760bcf5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'num_bytes' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49002) (comment: 03304_compare_substrings.sql) (query 14, line 21) (in query: select compareSubstrings('abc', 'abc', 0, 0, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.730622 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'num_bytes' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eef1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:40.793991 [ 3885 ] {1591e583-e769-4d5d-8876-c298ac4f296f} executeQuery: Code: 57. DB::Exception: Table test_3.numbers2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49020) (comment: 00578_merge_table_sampling.sql) (query 9, line 13) (in query: CREATE TABLE numbers2 ENGINE = MergeTree ORDER BY intHash32(number) SAMPLE BY intHash32(number) SETTINGS index_granularity = 23412, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 466602017, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 15915792, merge_max_block_size = 3403, old_parts_lifetime = 372., 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 = 8107677939, index_granularity_bytes = 23302074, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 27, 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 = 75776, primary_key_compress_block_size = 19302, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false AS SELECT number FROM numbers(1000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:40.817209 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.numbers2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:41.547836 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:41.559990 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:21:42.001907 [ 4468 ] {d552363b-9691-4dc9-8af7-1b0bcd136b44} executeQuery: Code: 60. DB::Exception: Table test_qumamwnh.t_json_async_insert does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49150) (comment: 02421_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d4002f9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d400fc5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:42.016083 [ 4468 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qumamwnh.t_json_async_insert does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d4002f9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d400fc5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:42.396992 [ 3885 ] {c5a8d20a-6a58-48db-b587-4fffc28a8938} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT count() FROM t_json_async_insert. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49192) (comment: 02421_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:42.412645 [ 3885 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT count() FROM t_json_async_insert. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:42.711480 [ 2824 ] {810eb6c6-7627-4c3f-990a-f9221c5bfaa0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49216) (comment: 01825_type_json_5.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:42.726604 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.184030 [ 6951 ] {3f3ea421-34e8-4a42-a7e4-a134992157e8} executeQuery: Code: 60. DB::Exception: Table test_qumamwnh.t_json_async_insert does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49266) (comment: 02421_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d4002f9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d400fc5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.189823 [ 3885 ] {9b46937c-46e5-4c43-b67b-873202c92adc} executeQuery: Code: 60. DB::Exception: Table test_qumamwnh.t_json_async_insert does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49272) (comment: 02421_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d4002f9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d400fc5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.220292 [ 3885 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qumamwnh.t_json_async_insert does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d4002f9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d400fc5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.223148 [ 6951 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qumamwnh.t_json_async_insert does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d4002f9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d400fc5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.609748 [ 3863 ] {494830d8-6964-4564-83a1-56a8ace85348} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49256) (comment: 02540_duplicate_primary_key.sql) (query 3, line 5) (in query: CREATE TABLE test (`coverage` DateTime, `haunt` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `sail` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `empowerment_turnstile` UInt8, `empowerment_haversack` Nullable(Int16), `empowerment_function` Nullable(Int16), `empowerment_guidance` Nullable(Int32), `empowerment_high` Nullable(Int32), `trading_id` Nullable(Int32), `guidance` Nullable(Int32), `empowerment_rawhide` Int32, `memo` Nullable(Int16), `oeuvre` Nullable(Int16), `bun` Nullable(Int16), `tramp` String, `anthropology_total` Nullable(Float32), `situation_name` String, `timing` Nullable(String), `NAME_cockroach` String, `NAME_toe` String, `business_error_methane` FixedString(110), `business_instrumentation_methane` FixedString(15), `market` UInt8, `crew_memo` Nullable(Int16), `crew_oeuvre` Nullable(Int16), `crew_fortnight` Nullable(Int16), `princess_memo` Nullable(Int16), `princess_oeuvre` Nullable(Int16), `princess_fortnight` Nullable(Int16), `emerald` Nullable(Float32), `cannon_crate` Nullable(String), `thinking` String, `SectorMen` String, `rage_name` Nullable(String), `DevelopmentalLigandName` String, `chard_heavy_quadrant` UInt64, `poster_effective` Nullable(String), PROJECTION chrysalis_trapezium_ham (SELECT empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), NAME_toe, NAME_cockroach, situation_name, memo, oeuvre, crew_memo, crew_oeuvre, bun, sum(multiIf(crew_memo IS NULL, 0, 1)), sum(multiIf(crew_oeuvre IS NULL, 0, 1)), sum(multiIf(crew_fortnight IS NULL, 0, 1)), max(toStartOfInterval(coverage, toIntervalDay(1))), max(CAST(CAST(toStartOfInterval(coverage, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), min(toStartOfInterval(coverage, toIntervalDay(1))), min(CAST(CAST(toStartOfInterval(coverage, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), count(), sum(1) GROUP BY empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), NAME_toe, NAME_cockroach, situation_name, memo, oeuvre, crew_memo, crew_oeuvre, bun)) ENGINE = MergeTree PARTITION BY toYYYYMM(coverage) ORDER BY (coverage, situation_name, NAME_toe, NAME_cockroach) SETTINGS index_granularity = 8482, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.3431779444217682, replace_long_file_name_to_hash = false, max_file_name_length = 96, min_bytes_for_full_part_storage = 305841345, compact_parts_max_bytes_to_buffer = 271717100, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 7869474, merge_max_block_size = 11756, 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 = 1, min_merge_bytes_to_use_direct_io = 654759580, index_granularity_bytes = 17862285, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 70690, primary_key_compress_block_size = 63272, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000030c8771d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c848df 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:842: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c85d90 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.644835 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000030c8771d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c848df 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:842: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c85d90 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.674272 [ 4468 ] {11075070-1210-4de1-82eb-77967a8ef7c2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT data.k1 FROM t_json_async_insert ORDER BY data.k1 ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49320) (comment: 02421_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.705860 [ 3815 ] {282696aa-4f49-4c9d-9663-b6d385ffa222} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:43.735841 [ 4468 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT data.k1 FROM t_json_async_insert ORDER BY data.k1 ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.747265 [ 3815 ] {282696aa-4f49-4c9d-9663-b6d385ffa222} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49076) (comment: 02373_analyzer_join_use_nulls.sql) (query 13, line 26) (in query: -- { echoOn } SELECT t1.id AS t1_id, toTypeName(t1_id), t1.value AS t1_value, toTypeName(t1_value), t2.id AS t2_id, toTypeName(t2_id), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:43.853936 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:45.850040 [ 2824 ] {da19675f-536c-4fe1-ac3d-3459b16ec44d} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49244) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: -- constant ignore will be pruned by part pruner. ignore(*) is used. SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:45.855900 [ 2824 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:45.995906 [ 2824 ] {c92bb0cc-8489-479d-996f-a3b300ecd6a9} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49244) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:45.998289 [ 2824 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:46.290786 [ 3815 ] {ccd6adf7-b3b8-4fb9-aec5-eeafc14745e3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49486) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:46.316643 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:21:49.074322 [ 3863 ] {7dc4e8b5-d86c-4121-88aa-90032ea2c124} 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([], rowNumberInBlock())). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49542) (comment: 00811_garbage.sql) (query 3, line 4) (in query: SELECT ( SELECT toDecimal128([], rowNumberInBlock()) ) , lcm('', [[(CAST(('>A') AS String))]]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b0518d1 8. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b0515e7 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:49.086920 [ 3863 ] {} 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([], rowNumberInBlock())). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b0518d1 8. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b0515e7 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:49.672743 [ 5379 ] {439b077f-3064-4598-ab7f-bf238e56ce2c} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49498) (comment: 02911_join_on_nullsafe_optimization.sql) (query 15, line 23) (in query: SELECT * FROM t1 JOIN t2 ON (t1.x <=> t2.x OR t1.x IS NULL AND t2.x IS NULL) OR t1.y <=> t2.y ORDER BY t1.x NULLS LAST;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:49.694645 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:21:49.742561 [ 4477 ] {00fbf54a-812e-4599-a846-36f74def6990} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type String: In scope SELECT mapPopulateSeries(['1', '2'], [1, 1]) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49420) (comment: 01318_map_populate_series.sql) (query 26, line 34) (in query: select mapPopulateSeries(['1', '2'], [1, 1]) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionMapPopulateSeries::checkTypes(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002392943d 6. DB::FunctionMapPopulateSeries::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000236519c4 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:49.747439 [ 4477 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type String: In scope SELECT mapPopulateSeries(['1', '2'], [1, 1]) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionMapPopulateSeries::checkTypes(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002392943d 6. DB::FunctionMapPopulateSeries::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000236519c4 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:49.873295 [ 3863 ] {e3226fc9-5822-4a74-8b5b-6ef536b71cd1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'idontexist' in scope SELECT 1 FROM idontexist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60202) (comment: 03326_client_ignore_error_multiquery.sh) (query 1, line 1) (in query: SELECT 1 FROM idontexist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:49.900224 [ 3863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'idontexist' in scope SELECT 1 FROM idontexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:21:49.939183 [ 4477 ] {9b071450-f8b9-454b-a361-e69a2a5d4a37} executeQuery: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2, 3], [1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49420) (comment: 01318_map_populate_series.sql) (query 27, line 35) (in query: select mapPopulateSeries([1, 2, 3], [1, 1]) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x00000000236537e9 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364ff3d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:49.949309 [ 4477 ] {} TCPHandler: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2, 3], [1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x00000000236537e9 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364ff3d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:50.021984 [ 4477 ] {7b12977f-e13b-4c38-a7d9-8b64868d6d73} executeQuery: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2], [1, 1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49420) (comment: 01318_map_populate_series.sql) (query 28, line 36) (in query: select mapPopulateSeries([1, 2], [1, 1, 1]) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x00000000236537e9 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364ff3d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:50.043265 [ 4477 ] {} TCPHandler: Code: 36. DB::Exception: Function mapPopulateSeries key and value array should have same amount of elements: In scope SELECT mapPopulateSeries([1, 2], [1, 1, 1]) AS res, toTypeName(res). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionMapPopulateSeries::extractKeyAndValueInput(std::vector> const&) const @ 0x00000000236537e9 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364ff3d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:50.703101 [ 6024 ] {fffa3090-8985-4b97-9413-530b17494f5b} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60266) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018dbf3d7 6. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dd0fe0 7. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dcdccb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018dbad09 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db85a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:21:50.720258 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018dbf3d7 6. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dd0fe0 7. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dcdccb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018dbad09 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db85a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:21:50.904429 [ 3863 ] {68b8b6da-7185-403d-987f-0b90d1a8cf88} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 1, line 4) (in query: --- aes_encrypt_mysql(string, key, block_mode[, init_vector, AAD]) -- The MySQL-compatitable encryption, only ecb, cbc and ofb modes are supported, -- just like for MySQL -- https://dev.mysql.com/doc/refman/8.0/en/encryption-functions.html#function_aes-encrypt -- https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_block_encryption_mode -- Please note that for keys that exceed mode-specific length, keys are folded in a MySQL-specific way, -- meaning that whole key is used, but effective key length is still determined by mode. -- when key doesn't exceed the default mode length, ecryption result equals with AES_encypt() ----------------------------------------------------------------------------------------- -- error cases ----------------------------------------------------------------------------------------- SELECT aes_encrypt_mysql();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:50.922220 [ 3863 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:51.037940 [ 3863 ] {86f50a75-2250-47a4-82e2-9bb79bee9152} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 2, line 17) (in query: SELECT aes_encrypt_mysql('aes-128-ecb');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:51.062188 [ 3863 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:51.227378 [ 4468 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:51.247946 [ 3863 ] {d2c96804-7f8f-4789-b271-de7bb4f3e290} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 3, line 18) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:51.250700 [ 3863 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:51.453282 [ 3863 ] {48e98c0c-717e-412e-846d-6450d22d8685} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: UInt16: In scope SELECT aes_encrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 4, line 20) (in query: SELECT aes_encrypt_mysql(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:51.461173 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: UInt16: In scope SELECT aes_encrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:51.636165 [ 3863 ] {a76b6588-7240-4fa7-b41a-2257455fe0ed} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 5, line 22) (in query: SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f15838 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:51.656571 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f15838 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:51.801562 [ 3863 ] {f16bd5c5-4d81-4f85-b7c7-4662a87aa410} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 6, line 23) (in query: SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f15838 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:51.816857 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f15838 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.069700 [ 3863 ] {814bcee3-a646-482d-9dd3-ac0d0ce06623} executeQuery: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 7, line 24) (in query: SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f159ab 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.081058 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f159ab 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.161194 [ 5382 ] {a16fb00e-169f-499e-8646-36433bb0decc} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column delta to destination column delta: while executing 'FUNCTION _CAST(delta :: 1, Int64 :: 2) -> _CAST(delta, Int64) Int64 : 3': while pushing to view test_13.src2dst_true (04af4065-138b-490c-b7bc-9dfedfbbcf1a). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 01947_mv_subquery.sql) (query 7, line 23) (in query: -- Inserting 2 numbers should require 2 calls to sleep INSERT into src SELECT number + 100 as id, 1 FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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 @ 0x000000002b005a07 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'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) @ 0x000000002b005734 7. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f113c5 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc55a1 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4361 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:52.194825 [ 5382 ] {} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column delta to destination column delta: while executing 'FUNCTION _CAST(delta :: 1, Int64 :: 2) -> _CAST(delta, Int64) Int64 : 3': while pushing to view test_13.src2dst_true (04af4065-138b-490c-b7bc-9dfedfbbcf1a). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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 @ 0x000000002b005a07 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'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) @ 0x000000002b005734 7. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f113c5 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc55a1 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4361 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:21:52.249801 [ 3863 ] {55865f2b-190b-47aa-aaf5-4fb905639c9c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: UInt16: In scope SELECT encrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 8, line 26) (in query: SELECT encrypt(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:52.272452 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: UInt16: In scope SELECT encrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:52.626469 [ 3863 ] {7d402660-5011-4d8b-abca-4407c0df9696} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT encrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 9, line 27) (in query: SELECT encrypt('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3cc3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.633116 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT encrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3cc3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.794279 [ 3863 ] {f5fcfdd0-0f47-46f2-ac5b-15f70a1e53b1} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT encrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 10, line 28) (in query: SELECT encrypt('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3cc3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.817987 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT encrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3cc3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:21:52.969724 [ 3863 ] {a6dd7afe-8dcf-4da7-93be-4c38f5d778b8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_encrypt_mysql'. Expected: encryption key binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 11, line 31) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:52.978905 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_encrypt_mysql'. Expected: encryption key binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:53.328610 [ 3863 ] {54039ae1-9b46-4281-a30e-a2789b9a91cf} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 12, line 33) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)0>::setKey(unsigned long, StringRef) @ 0x0000000018f1425a 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000018f161b5 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f155c7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:53.362876 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)0>::setKey(unsigned long, StringRef) @ 0x0000000018f1425a 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000018f161b5 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f155c7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:53.658321 [ 7056 ] {1ad14cdc-a149-4754-a781-e80f05ac3287} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60416) (comment: 02961_read_bool_as_string_json.sql) (query 4, line 4) (in query: select * from format(JSONEachRow, 'x String', '{"x" : tru}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: ? @ 0x0000000023b32d6e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:380: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c67eba1 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:865: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f2979 8. ./build_docker/./src/Formats/JSONUtils.cpp:303: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000317af8a5 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0791 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0ef9 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:21:53.669065 [ 7056 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: ? @ 0x0000000023b32d6e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:380: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c67eba1 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:865: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f2979 8. ./build_docker/./src/Formats/JSONUtils.cpp:303: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000317af8a5 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0791 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0ef9 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:21:53.678860 [ 3863 ] {7687944d-d353-48ec-8959-bb300790294c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 13, line 35) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:53.688271 [ 3863 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:53.787225 [ 7056 ] {d10dbede-2fbd-4080-ac4f-44502144c4ea} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60416) (comment: 02961_read_bool_as_string_json.sql) (query 5, line 5) (in query: select * from format(JSONEachRow, 'x String', '{"x" : fals}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: ? @ 0x0000000023b32d6e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:385: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c67f094 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:865: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f2979 8. ./build_docker/./src/Formats/JSONUtils.cpp:303: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000317af8a5 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0791 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0ef9 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:21:53.796270 [ 7056 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: ? @ 0x0000000023b32d6e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:385: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c67f094 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:865: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f2979 8. ./build_docker/./src/Formats/JSONUtils.cpp:303: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000317af8a5 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0791 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0ef9 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:21:53.820741 [ 3863 ] {2cf66589-1d3b-49c1-b0f0-f8a06cbaaffe} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'encrypt'. Expected: encryption key binary string, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 14, line 36) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:53.840625 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'encrypt'. Expected: encryption key binary string, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:21:54.129227 [ 3863 ] {777cd3ed-c929-47c7-b4d5-ba09a0697d13} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 15, line 37) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)1>::setKey(unsigned long, StringRef) const @ 0x000000001a062a4f 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a504a 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3a59 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:54.141273 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)1>::setKey(unsigned long, StringRef) const @ 0x000000001a062a4f 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a504a 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3a59 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:54.183566 [ 7056 ] {425affe0-7edf-44d9-b2c0-8d401f87bd53} executeQuery: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60416) (comment: 02961_read_bool_as_string_json.sql) (query 6, line 6) (in query: select * from format(JSONEachRow, 'x String', '{"x" : atru}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1774: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57b83 6. ./build_docker/./src/IO/ReadHelpers.cpp:1789: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x0000000023b37ce3 7. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:394: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c67edfe 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:865: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f2979 9. ./build_docker/./src/Formats/JSONUtils.cpp:303: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000317af8a5 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0791 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0ef9 12. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 22. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 23. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 24. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:21:54.189005 [ 7056 ] {} TCPHandler: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1774: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b57b83 6. ./build_docker/./src/IO/ReadHelpers.cpp:1789: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x0000000023b37ce3 7. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:394: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c67edfe 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:865: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f2979 9. ./build_docker/./src/Formats/JSONUtils.cpp:303: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000317af8a5 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0791 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa0ef9 12. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 22. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 23. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 24. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:21:54.237038 [ 3863 ] {f51f7c88-7527-4596-9ab7-dea9a5800f02} executeQuery: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 16, line 38) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)1>::setKey(unsigned long, StringRef) const @ 0x000000001a062a4f 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a504a 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3a59 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:54.318338 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)1>::setKey(unsigned long, StringRef) const @ 0x000000001a062a4f 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a504a 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3a59 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:54.505413 [ 5380 ] {ba7b8513-d13f-4530-b9c0-bdfe485f74c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58806) (comment: 03275_subcolumns_in_primary_key.gen.sql) (query 80, line 98) (in query: select count() from test where a.b.c = 0 and a.b.d = 'str_0' settings optimize_use_implicit_projections = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c66fd45 14. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 15. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:21:54.531531 [ 5380 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c66fd45 14. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 15. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:54.535334 [ 3863 ] {bca966a3-3967-47eb-929f-2a63cf70e485} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_encrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 17, line 40) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:54.541653 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_encrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:54.670410 [ 3863 ] {07d27016-8814-425e-8d7e-547dc36bc8ea} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 18, line 42) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)0>::setKey(unsigned long, StringRef) @ 0x0000000018f1425a 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000018f161b5 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f15691 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:54.705709 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. DB::OpenSSLDetails::KeyHolder<(DB::OpenSSLDetails::CipherMode)0>::setKey(unsigned long, StringRef) @ 0x0000000018f1425a 6. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000018f161b5 7. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f15691 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:21:55.013985 [ 3863 ] {ddefd787-7f0e-43b1-9948-b4e6475e1ca0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'encrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 19, line 44) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:55.020920 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'encrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:55.174230 [ 3863 ] {80383227-a396-4ca2-9210-40b608a1d568} executeQuery: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 20, line 45) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a58af 6. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3b31 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:55.200087 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a58af 6. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3b31 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:55.369690 [ 3863 ] {81f1403f-32b9-4eb9-b725-90ad77467816} executeQuery: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 21, line 46) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a58af 6. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3b31 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:55.409706 [ 3863 ] {} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1454f 5. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a6a58af 6. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6a3b31 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:21:55.571594 [ 3863 ] {329abea1-c4c2-442f-ad48-e5fa31a0b1fc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 22, line 48) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:55.581973 [ 3863 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018f15d34 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:55.832321 [ 3863 ] {1e4edd36-a580-49b3-a0f8-f0842858d485} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 23, line 51) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:55.872206 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:56.014222 [ 3863 ] {3ac14c11-fbbf-4e53-8246-cb390c7742b1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60292) (comment: 01318_encrypt.sql) (query 24, line 52) (in query: SELECT encrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:56.028499 [ 3863 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a42f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:21:57.784966 [ 4477 ] {32d44789-132c-44fb-b99d-caec4d24dde8} executeQuery: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60676) (comment: 03143_prewhere_profile_events.sh) (query 2, line 4) (in query: CREATE TABLE t(a UInt32, b UInt32, c UInt32, d UInt32) ENGINE=MergeTree ORDER BY a SETTINGS min_bytes_for_wide_part=0, min_rows_for_wide_part=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:57.824902 [ 4477 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:21:57.876533 [ 3766 ] {38af1862-148c-484c-af1c-9ed912dda934} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 52.82 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58666) (comment: 01062_pm_all_join_with_block_continuation.sql) (query 9, line 24) (in query: SELECT count(1) FROM ( SELECT materialize(1) as k, n FROM numbers(10) nums JOIN (SELECT materialize(1) AS k, number n FROM numbers(1000000)) j USING k);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc4a71 11. ./build_docker/./src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000002ffb9b77 12. ./src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000002de7ea37 13. ./build_docker/./src/Interpreters/MergeJoin.cpp:445: bool DB::(anonymous namespace)::joinEquals(DB::Block const&, DB::Block const&, DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::MergeJoinEqualRange&, unsigned long) @ 0x000000002de7bffd 14. ./build_docker/./src/Interpreters/MergeJoin.cpp:955: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x000000002de7ba88 15. ./build_docker/./src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de825bc 16. ./build_docker/./src/Interpreters/MergeJoin.cpp:749: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de7ac43 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000031dd51be 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000031dd4b84 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000031dd3e60 20. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000031dd2c04 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:21:57.895322 [ 5379 ] {0fc7e50b-9dcc-4e08-8ab2-6b2661afa267} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=846): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60604) (comment: 03274_philipzucker.sql) (query 2, line 5) (in query: WITH RECURSIVE digits AS ( SELECT 0 AS digit UNION ALL SELECT digit + 1 FROM digits WHERE digit < 9 ) SELECT s.digit AS S, e.digit AS E, n.digit AS N, d.digit AS D, m.digit AS M, o.digit AS O, r.digit AS R, y.digit AS Y FROM digits s, digits e, digits n, digits d, digits m, digits o, digits r, digits y WHERE s.digit <> e.digit AND s.digit <> n.digit AND s.digit <> d.digit AND s.digit <> m.digit AND s.digit <> o.digit AND s.digit <> r.digit AND s.digit <> y.digit AND e.digit <> n.digit AND e.digit <> d.digit AND e.digit <> m.digit AND e.digit <> o.digit AND e.digit <> r.digit AND e.digit <> y.digit AND n.digit <> d.digit AND n.digit <> m.digit AND n.digit <> o.digit AND n.digit <> r.digit AND n.digit <> y.digit AND d.digit <> m.digit AND d.digit <> o.digit AND d.digit <> r.digit AND d.digit <> y.digit AND m.digit <> o.digit AND m.digit <> r.digit AND m.digit <> y.digit AND o.digit <> r.digit AND o.digit <> y.digit AND r.digit <> y.digit AND s.digit <> 0 AND m.digit <> 0 AND (1000 * s.digit + 100 * e.digit + 10 * n.digit + d.digit) + (1000 * m.digit + 100 * o.digit + 10 * r.digit + e.digit) = (10000 * m.digit + 1000 * o.digit + 100 * n.digit + 10 * e.digit + y.digit);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:134: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223524b 9. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:21:57.896557 [ 3766 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 52.82 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc4a71 11. ./build_docker/./src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000002ffb9b77 12. ./src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000002de7ea37 13. ./build_docker/./src/Interpreters/MergeJoin.cpp:445: bool DB::(anonymous namespace)::joinEquals(DB::Block const&, DB::Block const&, DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::MergeJoinEqualRange&, unsigned long) @ 0x000000002de7bffd 14. ./build_docker/./src/Interpreters/MergeJoin.cpp:955: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x000000002de7ba88 15. ./build_docker/./src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de825bc 16. ./build_docker/./src/Interpreters/MergeJoin.cpp:749: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de7ac43 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000031dd51be 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000031dd4b84 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000031dd3e60 20. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000031dd2c04 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:57.997476 [ 5379 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=846): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:134: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223524b 9. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.052803 [ 5971 ] {5716b6d1-d462-42e2-8c1e-e9553c0f8b76} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02174_cte_scalar_cache_mv.sql) (in query: /* ddl_entry=query-0000000106 */ CREATE TABLE test_5.t1 UUID '9728251e-8862-42d2-af16-733bc42b1058' (`i` Int64, `j` Int64) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.132696 [ 5971 ] {5716b6d1-d462-42e2-8c1e-e9553c0f8b76} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60686) (comment: 02174_cte_scalar_cache_mv.sql) (query 1, line 1) (in query: -- TEST CACHE CREATE TABLE t1 (i Int64, j Int64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.145172 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.188056 [ 4477 ] {2023314275} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `c` in scope SELECT * FROM t PREWHERE (b % 8192) = 42 WHERE c = 42. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60696) (comment: 03143_prewhere_profile_events.sh) (query 1, line 2) (in query: SELECT * FROM t PREWHERE (b % 8192) = 42 WHERE c = 42 FORMAT Null ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.283768 [ 4477 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `c` in scope SELECT * FROM t PREWHERE (b % 8192) = 42 WHERE c = 42. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.295007 [ 3766 ] {d9a0a4a5-e347-49c7-8e03-766f0499219a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 50.05 MiB (attempt to allocate chunk of 31.00 MiB bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58666) (comment: 01062_pm_all_join_with_block_continuation.sql) (query 10, line 29) (in query: SELECT count(1) FROM ( SELECT materialize(1) as k, n FROM numbers(1000) nums JOIN (SELECT materialize(1) AS k, number n FROM numbers(10000)) j USING k);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc4a71 11. ./build_docker/./src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000002ffb9b77 12. ./src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000002de7ea37 13. ./build_docker/./src/Interpreters/MergeJoin.cpp:445: bool DB::(anonymous namespace)::joinEquals(DB::Block const&, DB::Block const&, DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::MergeJoinEqualRange&, unsigned long) @ 0x000000002de7bffd 14. ./build_docker/./src/Interpreters/MergeJoin.cpp:955: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x000000002de7ba88 15. ./build_docker/./src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de825bc 16. ./build_docker/./src/Interpreters/MergeJoin.cpp:749: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de7ac43 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000031dd51be 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000031dd4b84 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000031dd3e60 20. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000031dd2c04 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.302478 [ 3766 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 50.05 MiB (attempt to allocate chunk of 31.00 MiB bytes), maximum: 47.68 MiB.: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc4c26 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc4a71 11. ./build_docker/./src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000002ffb9b77 12. ./src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000002de7ea37 13. ./build_docker/./src/Interpreters/MergeJoin.cpp:445: bool DB::(anonymous namespace)::joinEquals(DB::Block const&, DB::Block const&, DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::MergeJoinEqualRange&, unsigned long) @ 0x000000002de7bffd 14. ./build_docker/./src/Interpreters/MergeJoin.cpp:955: DB::MergeJoin::allInnerJoin(DB::MergeJoinCursor&, DB::Block const&, DB::MergeJoin::RightBlockInfo&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long&) @ 0x000000002de7ba88 15. ./build_docker/./src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de825bc 16. ./build_docker/./src/Interpreters/MergeJoin.cpp:749: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002de7ac43 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000031dd51be 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000031dd4b84 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000031dd3e60 20. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000031dd2c04 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:21:58.657945 [ 2824 ] {1270527839} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `c` in scope SELECT * FROM t PREWHERE ((b % 8192) = 42) AND ((c % 8192) = 42) WHERE d = 42. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60706) (comment: 03143_prewhere_profile_events.sh) (query 1, line 2) (in query: SELECT * FROM t PREWHERE (b % 8192) = 42 AND (c % 8192) = 42 WHERE d = 42 FORMAT Null settings enable_multiple_prewhere_read_steps=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5599: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05276 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:21:58.680504 [ 2824 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `c` in scope SELECT * FROM t PREWHERE ((b % 8192) = 42) AND ((c % 8192) = 42) WHERE d = 42. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5599: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05276 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:21:58.952247 [ 10341 ] {357816202} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `c` in scope SELECT * FROM t PREWHERE ((b % 8192) = 42) AND ((c % 16384) = 42) WHERE d = 42. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42674) (comment: 03143_prewhere_profile_events.sh) (query 1, line 2) (in query: SELECT * FROM t PREWHERE (b % 8192) = 42 AND (c % 16384) = 42 WHERE d = 42 FORMAT Null settings enable_multiple_prewhere_read_steps=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5599: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05276 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:21:58.960681 [ 10341 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `c` in scope SELECT * FROM t PREWHERE ((b % 8192) = 42) AND ((c % 16384) = 42) WHERE d = 42. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5599: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05276 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:21:59.251968 [ 6024 ] {2036712693} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT b, c FROM t PREWHERE ((b % 8192) = 42) AND ((c % 8192) = 42). Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42686) (comment: 03143_prewhere_profile_events.sh) (query 1, line 2) (in query: SELECT b, c FROM t PREWHERE (b % 8192) = 42 AND (c % 8192) = 42 FORMAT Null settings enable_multiple_prewhere_read_steps=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:21:59.255936 [ 6024 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT b, c FROM t PREWHERE ((b % 8192) = 42) AND ((c % 8192) = 42). Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:22:00.875977 [ 6024 ] {7440f702-eef9-4afd-8a0b-a1e7cc218d78} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_o4yzfijx.default_constraints (dab44ad9-e2eb-4675-bf3f-19dcdaa37203) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42768) (comment: 01286_constraints_on_default.sql) (query 3, line 9) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:00.901932 [ 6024 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_o4yzfijx.default_constraints (dab44ad9-e2eb-4675-bf3f-19dcdaa37203) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:22:01.070827 [ 6024 ] {457d281a-2bf4-4af3-b758-f3a78123294b} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_o4yzfijx.default_constraints (dab44ad9-e2eb-4675-bf3f-19dcdaa37203) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42768) (comment: 01286_constraints_on_default.sql) (query 4, line 10) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:01.074914 [ 6024 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_o4yzfijx.default_constraints (dab44ad9-e2eb-4675-bf3f-19dcdaa37203) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:01.633229 [ 6024 ] {fa7677c5-91ef-4178-b284-4f2c4b2b3ba6} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_90d2a9b1-d0a0-4e90-a651-04878c566212` (90d2a9b1-d0a0-4e90-a651-04878c566212) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42768) (comment: 01286_constraints_on_default.sql) (query 9, line 25) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:01.638033 [ 6024 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_90d2a9b1-d0a0-4e90-a651-04878c566212` (90d2a9b1-d0a0-4e90-a651-04878c566212) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:22:01.776685 [ 4477 ] {b2108a8d-72d4-4316-aa5f-11dc63a681bd} 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.3.20372.altinityantalya (altinity build)) (from [::1]:60714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001e64b18b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e0b3611 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:22:01.788440 [ 4477 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001e64b18b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e0b3611 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:22:01.907000 [ 6024 ] {71bbdf62-effe-402f-af8c-9451ae30236d} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_90d2a9b1-d0a0-4e90-a651-04878c566212` (90d2a9b1-d0a0-4e90-a651-04878c566212) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42768) (comment: 01286_constraints_on_default.sql) (query 10, line 26) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:01.923121 [ 6024 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_90d2a9b1-d0a0-4e90-a651-04878c566212` (90d2a9b1-d0a0-4e90-a651-04878c566212) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5f8017 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031daa4a8 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:02.089518 [ 4477 ] {8ea01441-6119-4e1b-821a-1267dff30ce1} 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.3.20372.altinityantalya (altinity build)) (from [::1]:60714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de79b24 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de74a9c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de710e0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6efa8 9. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de78cd6 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de74a9c 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de710e0 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6efa8 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:22:02.099557 [ 4477 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de79b24 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de74a9c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de710e0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6efa8 9. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de78cd6 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de74a9c 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de710e0 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6efa8 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:22:02.992894 [ 4477 ] {042b2296-4f91-452f-963c-a83fc13e0ff4} 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.3.20372.altinityantalya (altinity build)) (from [::1]:60714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd130a4 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ecdc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:03.012860 [ 4477 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd130a4 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ecdc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:03.113083 [ 5382 ] {f4ccf1a6-c244-49f3-aa54-c20feee8b9f5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:58758) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000031b5dd71 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003184b0e9 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:03.118505 [ 5382 ] {f4ccf1a6-c244-49f3-aa54-c20feee8b9f5} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5ccbd 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b5aaf6 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000031b5dd71 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003184b0e9 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:03.316581 [ 2825 ] {06be1315-974a-49b5-b024-a82c06c5d724} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56700) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: DROP DATABASE IF EXISTS test_rx5nwmnf SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:03.318018 [ 2825 ] {06be1315-974a-49b5-b024-a82c06c5d724} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:03.536235 [ 5380 ] {6440429b-8711-4dac-97a4-e54fc3db1a93} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60574) (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 = 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 = 242167945, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 16037322, merge_max_block_size = 8416, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 2365138, 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 = 66481, primary_key_compress_block_size = 63836, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:03.547776 [ 5380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:04.873783 [ 3885 ] {8949a47e-e809-416d-ab28-6b270bd04ceb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58164) (comment: 01104_distributed_numbers_test.sql) (in query: DROP DATABASE IF EXISTS test_6fpo5338 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:04.875196 [ 3885 ] {8949a47e-e809-416d-ab28-6b270bd04ceb} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:05.577244 [ 4938 ] {4c36731f-312c-4069-90c7-68fb7de40b81} executeQuery: Code: 57. DB::Exception: Table test_13.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43010) (comment: 02317_distinct_in_order_optimization.sql) (query 13, line 14) (in query: CREATE TABLE distinct_in_order (`a` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 10, min_bytes_for_wide_part = 789685554, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 67, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 453040026, compact_parts_max_granules_to_buffer = 183, compact_parts_merge_max_bytes_to_prefetch_part = 3735487, merge_max_block_size = 20232, old_parts_lifetime = 400., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 42, min_merge_bytes_to_use_direct_io = 5819676553, index_granularity_bytes = 13967277, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 13152, primary_key_compress_block_size = 66793, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:05.588819 [ 4938 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.distinct_in_order already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:05.900402 [ 3885 ] {3e5e7386-665a-473e-adc8-96c7e2c17284} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43178) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:05.929153 [ 3885 ] {} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.640492 [ 2825 ] {cb2fcffc-40cd-4e03-9a74-37f1b13b6b31} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43220) (comment: 01478_not_equi-join_on.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = foo.b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x00000000321479c7 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.649779 [ 2825 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x00000000321479c7 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.692056 [ 4477 ] {7c9f88ff-7cf0-404b-822e-299d13ec034f} executeQuery: Code: 497. DB::Exception: without_on_cluster_02250_ON_CLUSTER_grant_test_k05uqqbl: Not enough privileges. To execute this query, it's necessary to have the grant CLUSTER ON *.*. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43234) (comment: 02250_ON_CLUSTER_grant.sh) (query 1, line 1) (in query: CREATE DATABASE IF NOT EXISTS db_without_on_cluster_02250_ON_CLUSTER_grant_test_k05uqqbl ON CLUSTER test_shard_localhost), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58dbc 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x000000002bd57fb1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd57518 7. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 8. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 9. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:114: DB::executeDDLQueryOnCluster(std::shared_ptr const&, std::shared_ptr, DB::DDLQueryOnClusterParams const&) @ 0x000000002e290fd4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2314: DB::InterpreterCreateQuery::executeQueryOnCluster(DB::ASTCreateQuery&) @ 0x000000002dc81b44 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2334: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94cea 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.736678 [ 4477 ] {} TCPHandler: Code: 497. DB::Exception: without_on_cluster_02250_ON_CLUSTER_grant_test_k05uqqbl: Not enough privileges. To execute this query, it's necessary to have the grant CLUSTER ON *.*. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58dbc 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x000000002bd57fb1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd57518 7. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 8. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 9. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:114: DB::executeDDLQueryOnCluster(std::shared_ptr const&, std::shared_ptr, DB::DDLQueryOnClusterParams const&) @ 0x000000002e290fd4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2314: DB::InterpreterCreateQuery::executeQueryOnCluster(DB::ASTCreateQuery&) @ 0x000000002dc81b44 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2334: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94cea 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.845100 [ 2825 ] {c3ea018a-fa62-4f12-9715-9760fff4a52e} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: () Right filter: ((equals(1_UInt8, __table3.b)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43220) (comment: 01478_not_equi-join_on.sql) (query 2, line 5) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = bar.b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x00000000321479c7 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.868937 [ 2825 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: () Right filter: ((equals(1_UInt8, __table3.b)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x00000000321479c7 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:06.964348 [ 5382 ] {7dc9d868-1539-4569-81ce-ab7ef9ce9c63} executeQuery: Code: 36. DB::Exception: Invalid arguments, key_value_delimiter conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 23, line 294) (in query: -- { echoOff } -- cross parameter validation tests -- should fail because key value delimiter conflicts with pair delimiters WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:69: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002398f456 6. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002398effc 7. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000023984cfb 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002398449b 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983dfd 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:06.980941 [ 5382 ] {} TCPHandler: Code: 36. DB::Exception: Invalid arguments, key_value_delimiter conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:69: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002398f456 6. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002398effc 7. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000023984cfb 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002398449b 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983dfd 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:07.145001 [ 6951 ] {1008418b-c293-4115-8c4e-a0416588d149} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43180) (comment: 00550_join_insert_select.sh) (query 9, line 12) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY INNER JOIN test3_00550 USING (id) SETTINGS any_join_distinct_right_table_keys=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:07.146207 [ 5382 ] {78f7f7f2-72fc-4a4b-b0ba-756fa5d2ff48} executeQuery: Code: 36. DB::Exception: Control character argument must either be empty or contain exactly 1 character: In scope WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 24, line 309) (in query: -- should fail because key value delimiter conflicts with quoting characters WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:94: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000023981733 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980d6b 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 2025.07.13 02:22:07.156722 [ 6951 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:07.157703 [ 5382 ] {} TCPHandler: Code: 36. DB::Exception: Control character argument must either be empty or contain exactly 1 character: In scope WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:94: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000023981733 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980d6b 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 2025.07.13 02:22:07.294981 [ 2825 ] {4cc85389-c791-4bc0-a355-ba0a416c2435} executeQuery: Code: 57. DB::Exception: Table test_juig5mwp.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43298) (comment: 02661_read_from_archive_tarxz.sh) (query 1, line 1) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_juig5mwp_tarxz_archive{1,2}.tar.xz :: 02661_read_from_archive_test_juig5mwp_tarxz_data{1,3}.csv')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:07.336977 [ 2825 ] {} TCPHandler: Code: 57. DB::Exception: Table test_juig5mwp.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:07.438448 [ 5382 ] {2d56afde-1733-4fae-842e-51259588fe32} executeQuery: Code: 36. DB::Exception: Invalid arguments, quoting_character conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 25, line 321) (in query: -- should fail because pair delimiters conflicts with quoting characters WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:77: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002398f4b2 6. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002398effc 7. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000023984cfb 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002398449b 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983dfd 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:07.458905 [ 5382 ] {} TCPHandler: Code: 36. DB::Exception: Invalid arguments, quoting_character conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:77: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002398f4b2 6. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002398effc 7. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000023984cfb 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002398449b 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983dfd 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:07.529679 [ 6951 ] {fab5d4e5-e84e-4133-887b-457aaf5cc816} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43180) (comment: 00550_join_insert_select.sh) (query 10, line 13) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY LEFT OUTER JOIN test3_00550 USING (id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:07.542212 [ 6951 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:07.729589 [ 5382 ] {28a4a22b-df57-482e-bc57-a66fc515115b} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument data_column. Must be String.: In scope WITH extractKeyValuePairs([1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 26, line 333) (in query: -- should fail because data_column argument must be of type String WITH extractKeyValuePairs([1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:102: DB::ArgumentExtractor::extractStringColumn(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000023981321 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:43: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000239809a5 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:07.747597 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument data_column. Must be String.: In scope WITH extractKeyValuePairs([1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:102: DB::ArgumentExtractor::extractStringColumn(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000023981321 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:43: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000239809a5 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:07.843550 [ 5382 ] {dc73249e-27b4-436b-8c8a-a5f8056ef058} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument key_value_delimiter. Must be String.: In scope WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 27, line 345) (in query: -- should fail because key_value_delimiter argument must be of type String WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000002398159d 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:50: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980ade 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:07.861810 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument key_value_delimiter. Must be String.: In scope WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000002398159d 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:50: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980ade 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.171478 [ 5382 ] {ae59deb3-d22c-4e10-bda5-672b23332c6b} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument pair_delimiters. Must be String.: In scope WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 28, line 357) (in query: -- should fail because pair_delimiters argument must be of type String WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:112: DB::ArgumentExtractor::extractVector(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000023981820 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:57: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980c25 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.194293 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument pair_delimiters. Must be String.: In scope WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:112: DB::ArgumentExtractor::extractVector(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000023981820 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:57: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980c25 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.332502 [ 5382 ] {c278be80-b055-491f-af94-8b2f422bc9c9} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument quoting_character. Must be String.: In scope WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 29, line 369) (in query: -- should fail because quoting_character argument must be of type String WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000002398159d 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980d6b 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.344650 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument quoting_character. Must be String.: In scope WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x0000000023981ccf 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x0000000023981ac6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000002398159d 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x0000000023980d6b 8. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.589737 [ 5382 ] {00e15b15-0049-4ad7-96ff-dc9a9e55f531} executeQuery: Code: 36. DB::Exception: Invalid arguments, pair delimiters can contain at most 8 characters: In scope WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 30, line 381) (in query: -- should fail because pair delimiters can contain at most 8 characters WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int const&) @ 0x000000002398f82f 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:56: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002398f378 6. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002398effc 7. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000023984cfb 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002398449b 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983dfd 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.601168 [ 5382 ] {} TCPHandler: Code: 36. DB::Exception: Invalid arguments, pair delimiters can contain at most 8 characters: In scope WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int const&) @ 0x000000002398f82f 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:56: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002398f378 6. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002398effc 7. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000023984cfb 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002398449b 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983dfd 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:08.916113 [ 5382 ] {970e8248-6209-4d61-a695-c32aa33ef6ef} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope WITH extractKeyValuePairs() AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 31, line 393) (in query: -- should fail because no argument has been provided WITH extractKeyValuePairs() AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x0000000023981c4f 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002398100f 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 2025.07.13 02:22:08.940298 [ 5382 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope WITH extractKeyValuePairs() AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x0000000023981c4f 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002398100f 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 2025.07.13 02:22:09.043227 [ 5382 ] {c8342842-c671-459c-b7aa-480389fe4fdf} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 5 was provided: In scope WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 32, line 405) (in query: -- should fail because one extra argument / non existent has been provided WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x0000000023981c4f 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002398100f 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 2025.07.13 02:22:09.053940 [ 5382 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 5 was provided: In scope WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x0000000023981c4f 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002398100f 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x00000000239808d7 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983daa 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 2025.07.13 02:22:09.213726 [ 4938 ] {727fde38-556d-42a8-a1b3-c6f445d75cbe} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43832) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:09.223260 [ 4938 ] {} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:09.252422 [ 5382 ] {3b3bc089-1bc4-49ce-9506-bfb85d4a8137} executeQuery: Code: 290. DB::Exception: Number of pairs produced exceeded the limit of 1: In scope WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42954) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 34, line 419) (in query: WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:119: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::flushPair(std::basic_string_view> const&, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x0000000023987d80 6. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:104: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::processState(std::basic_string_view>, DB::extractKV::StateHandler::State, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x00000000239867db 7. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:49: DB::extractKV::KeyValuePairExtractor::extractImpl(std::basic_string_view>, DB::extractKV::NoEscapingStateHandler::PairWriter&) @ 0x00000000239863e9 8. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:149: COW::immutable_ptr DB::ExtractKeyValuePairs::extract(COW::immutable_ptr, DB::KeyValuePairExtractorNoEscaping&, unsigned long) const @ 0x0000000023984769 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:112: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983e36 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:09.266786 [ 5382 ] {} TCPHandler: Code: 290. DB::Exception: Number of pairs produced exceeded the limit of 1: In scope WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:119: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::flushPair(std::basic_string_view> const&, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x0000000023987d80 6. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:104: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::processState(std::basic_string_view>, DB::extractKV::StateHandler::State, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x00000000239867db 7. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:49: DB::extractKV::KeyValuePairExtractor::extractImpl(std::basic_string_view>, DB::extractKV::NoEscapingStateHandler::PairWriter&) @ 0x00000000239863e9 8. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:149: COW::immutable_ptr DB::ExtractKeyValuePairs::extract(COW::immutable_ptr, DB::KeyValuePairExtractorNoEscaping&, unsigned long) const @ 0x0000000023984769 9. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:112: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023983e36 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c9b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 2025.07.13 02:22:12.653337 [ 3885 ] {f16c5be8-b042-43d3-97c8-e0aeb576d590} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44290) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:12.666916 [ 3885 ] {} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:13.234603 [ 3641 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003117f00d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003117ef02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x0000000032823380 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x00000000328210b2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x000000003281ffaf 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003282d1fe 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.245740 [ 3169 ] {} test_7.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.252132 [ 3163 ] {} test_1.t1_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.254897 [ 3160 ] {} test_3.deduplication (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.256954 [ 3152 ] {} test_3.dst (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.258725 [ 3171 ] {} test_1.t1_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.260834 [ 3175 ] {} test_7.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.264713 [ 3164 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.274196 [ 3180 ] {} test_11.table_rename_with_ttl (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.276990 [ 3177 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.286751 [ 3162 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:13.333578 [ 3159 ] {} test_7.clear_column1 (929ba98e-438e-46ac-bb5b-609fb4eb8cf2): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_7/test_00446/tables/clear_column/mutations. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af99c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af994d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275eecf 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:653: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003110e584 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003063fc15 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.333635 [ 3450 ] {} 1a225c10-67e9-474e-aab0-327a9b66edb0::200002_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_7/test_00446/tables/clear_column/replicas/1/parts/200002_1_1_0_3. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af99c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af994d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763def 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:250: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x00000000327ffdd7 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2030: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000305d33f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2123: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x00000000305d8148 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2175: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000305dac03 12. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000003101436e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310ba16c 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310b7919 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.335789 [ 3450 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1a225c10-67e9-474e-aab0-327a9b66edb0::200002_1_1_0_3}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_7/test_00446/tables/clear_column/replicas/1/parts/200002_1_1_0_3. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af99c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af994d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763def 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:250: DB::ZooKeeperWithFaultInjection::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x00000000327ffdd7 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2030: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000305d33f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2123: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x00000000305d8148 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2175: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000305dac03 12. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000003101436e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310ba16c 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310b7919 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.365635 [ 3153 ] {} test_7.clear_column1 (929ba98e-438e-46ac-bb5b-609fb4eb8cf2): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_7/test_00446/tables/clear_column/replicas/1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003063ff0f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.365690 [ 3158 ] {} test_7.clear_column1 (929ba98e-438e-46ac-bb5b-609fb4eb8cf2): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003110de84 13. ./build_docker/./src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x0000000031246808 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000031145952 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, std::allocator, 0>(std::allocator, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000311455bf 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>, 0>(std::allocator const&, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000031145426 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003112da1a 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4159: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x0000000030646357 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4192: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x0000000030642e4f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 21. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 22. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.370997 [ 3172 ] {} test_7.clear_column2 (1a225c10-67e9-474e-aab0-327a9b66edb0): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.380090 [ 3033 ] {} test_7.clear_column1 (929ba98e-438e-46ac-bb5b-609fb4eb8cf2): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.413125 [ 3135 ] {} test_7.clear_column2 (1a225c10-67e9-474e-aab0-327a9b66edb0): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003110de84 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003063fc15 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.426769 [ 6024 ] {78b1eb6d-edb7-494a-9592-73f3cf035a99} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44342) (comment: 00443_optimize_final_vertical_merge.sh) (query 1, line 1) (in query: CREATE TABLE test_5.optimize_me_finally ( date Date, Sign Int8, ki UInt64, ds String, di01 UInt64, di02 UInt64, di03 UInt64, di04 UInt64, di05 UInt64, di06 UInt64, di07 UInt64, di08 UInt64, di09 UInt64, di10 UInt64, n Nested( i UInt64, s String ) ) ENGINE = CollapsingMergeTree(date, (date, ki), 8192, Sign)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000032755c1c 5. ./build_docker/./src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x0000000032755b19 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:823: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x00000000327655d7 7. ./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&)>) @ 0x000000002c7a85d4 8. ./src/Common/ZooKeeper/ZooKeeper.h:344: zkutil::MultiReadResponses zkutil::ZooKeeper::tryGet>(std::__wrap_iter, std::__wrap_iter) @ 0x000000002c7a8164 9. ./src/Common/ZooKeeper/ZooKeeper.h:350: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c783d4e 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:13.429473 [ 3109 ] {} test_7.clear_column2 (1a225c10-67e9-474e-aab0-327a9b66edb0): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000032755c1c 5. ./build_docker/./src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x0000000032755b19 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1620: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654f7 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:810: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003276539c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:745: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000031111749 9. ./build_docker/./src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x0000000031246808 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000031145952 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, std::allocator, 0>(std::allocator, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000311455bf 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>, 0>(std::allocator const&, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000031145426 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003112da1a 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4159: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x0000000030646357 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4192: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x0000000030642e4f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:13.470065 [ 6024 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000032755c1c 5. ./build_docker/./src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x0000000032755b19 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:823: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x00000000327655d7 7. ./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&)>) @ 0x000000002c7a85d4 8. ./src/Common/ZooKeeper/ZooKeeper.h:344: zkutil::MultiReadResponses zkutil::ZooKeeper::tryGet>(std::__wrap_iter, std::__wrap_iter) @ 0x000000002c7a8164 9. ./src/Common/ZooKeeper/ZooKeeper.h:350: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c783d4e 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:13.475937 [ 4142 ] {a3bb7ceb-df08-47f5-8b45-d87e378ff5dc} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60512) (comment: 00446_clear_column_in_partition_zookeeper_long.sql) (query 37, line 56) (in query: ALTER TABLE clear_column1 CLEAR COLUMN i IN PARTITION '200002';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1479: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003282976b 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1290: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x00000000327627de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:561: zkutil::ZooKeeper::existsImpl(String const&, Coordination::Stat*, std::function) @ 0x00000000327622b7 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:595: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000032762a76 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003275fad8 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:778: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000305a4990 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7981: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000030691b07 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6719: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003068e716 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:13.502316 [ 4142 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1479: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003282976b 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1290: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x00000000327627de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:561: zkutil::ZooKeeper::existsImpl(String const&, Coordination::Stat*, std::function) @ 0x00000000327622b7 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:595: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000032762a76 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003275fad8 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:778: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000305a4990 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7981: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000030691b07 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6719: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003068e716 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:13.947718 [ 5971 ] {431c7289-0d05-4a1e-b58a-6623de5d947a} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44478) (comment: 01761_alter_decimal_zookeeper_long.sql) (query 2, line 5) (in query: CREATE TABLE test_alter_decimal (n UInt64, d Decimal(15, 8)) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/01761_alter_decimal_zookeeper', 'r1') ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:14.085373 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:14.421769 [ 6024 ] {d686737c-cfbc-485e-9db4-53f25f16bfd2} executeQuery: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47226) (comment: 02009_from_infile.sh) (in query: INSERT INTO test_infile_url FROM INFILE '/repo/tests/queries/0_stateless/test_icc339yi/test_infile.gz' FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000031f16b60 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcef996 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:22:14.424287 [ 6024 ] {d686737c-cfbc-485e-9db4-53f25f16bfd2} DynamicQueryHandler: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000031f16b60 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcef996 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:14.933606 [ 3301 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d604150 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d6048e1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:15.061548 [ 4938 ] {ac6866cb-85bd-4232-be97-22e4e37a473b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52282) (comment: 02009_from_infile.sh) (in query: DROP DATABASE IF EXISTS test_icc339yi SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:15.076086 [ 4938 ] {ac6866cb-85bd-4232-be97-22e4e37a473b} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:16.024383 [ 7056 ] {582214d7-dee4-4006-b6fb-8a2970391812} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44716) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:16.035440 [ 7056 ] {} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:16.524631 [ 6942 ] {643b3247-99f9-4dec-9d0c-38bb9df6e929} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_7.t_async_inserts_logs (id, s) FORMAT JSONEachRow' with query id eb9660bd-323e-42c0-9cd7-fefa07a987d0. DB::Exception: Cannot parse input: expected '{' before: 'qqqqqq': (at row 1) 2025.07.13 02:22:16.524702 [ 3665 ] {aec4ad0f-5cca-4fa8-be97-a54e9a32c44e} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_7.t_async_inserts_logs (id, s) FORMAT Values' with query id 36d73278-916a-487e-b8f5-762821836964. DB::Exception: Cannot parse input: expected '(' before: 'qqqqqq': at row 0 2025.07.13 02:22:16.553493 [ 6951 ] {36d73278-916a-487e-b8f5-762821836964} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' before: 'qqqqqq': at row 0: While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47288) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO t_async_inserts_logs VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d43b29 6. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:16.562573 [ 4938 ] {eb9660bd-323e-42c0-9cd7-fefa07a987d0} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'qqqqqq': (at row 1) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47264) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO t_async_inserts_logs FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa13f0 6. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:16.565707 [ 6951 ] {36d73278-916a-487e-b8f5-762821836964} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' before: 'qqqqqq': at row 0: While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000031d43b29 6. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000031d410ed 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:16.567214 [ 4938 ] {eb9660bd-323e-42c0-9cd7-fefa07a987d0} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'qqqqqq': (at row 1) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000031aa13f0 6. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031aa19b6 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x0000000031846db2 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000031846885 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d4098ff 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:18.027895 [ 4477 ] {8656a7dc-ff02-4874-996a-a1a7e6572b2c} executeQuery: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44792) (comment: 03243_check_for_nullable_nothing_in_alter.sql) (query 5, line 5) (in query: alter table src modify column x Nullable(Nothing);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000303d40fb 6. ./build_docker/./src/Storages/AlterCommands.cpp:1534: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d4212 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.032286 [ 4477 ] {} TCPHandler: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000303d40fb 6. ./build_docker/./src/Storages/AlterCommands.cpp:1534: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d4212 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.101175 [ 5382 ] {43608a46-bea6-4982-9a06-e746601cc535} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03248_max_parts_to_move.sql) (in query: /* ddl_entry=query-0000000112 */ ALTER TABLE test_5.t (MOVE PARTITION tuple() TO TABLE t2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long const&) @ 0x000000002bf942af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2399: DB::StorageMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031210e28 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.187319 [ 5382 ] {43608a46-bea6-4982-9a06-e746601cc535} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44562) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long const&) @ 0x000000002bf942af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2399: DB::StorageMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031210e28 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.207239 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long const&) @ 0x000000002bf942af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2399: DB::StorageMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000031210e28 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.212008 [ 6921 ] {6594c404-b453-4e48-afa7-11c4bcb83c2e} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 186.00 B) in table 'test_7.t_async_inserts_logs (9e183fbd-455c-46dd-88d4-577df172c864)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO test_7.t_async_inserts_logs (id, s) FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d795cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cfdc8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4632 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.216856 [ 6921 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_7.t_async_inserts_logs (id, s) FORMAT Values': Code: 252. DB::Exception: Too many parts (1 with average size of 186.00 B) in table 'test_7.t_async_inserts_logs (9e183fbd-455c-46dd-88d4-577df172c864)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d795cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cfdc8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4632 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:18.220573 [ 4938 ] {2608f2e8-b780-4f0e-b77a-d325d0886da0} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 186.00 B) in table 'test_7.t_async_inserts_logs (9e183fbd-455c-46dd-88d4-577df172c864)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47326) (comment: 02456_async_inserts_logs.sh) (in query: INSERT INTO t_async_inserts_logs VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d795cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cfdc8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4632 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.222483 [ 4938 ] {2608f2e8-b780-4f0e-b77a-d325d0886da0} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 186.00 B) in table 'test_7.t_async_inserts_logs (9e183fbd-455c-46dd-88d4-577df172c864)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d795cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cfdc8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4632 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:18.388383 [ 4477 ] {0b7a9e71-cf83-4131-92ef-5e5808dff7e9} executeQuery: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44792) (comment: 03243_check_for_nullable_nothing_in_alter.sql) (query 8, line 8) (in query: alter table v modify query select NULL as x from src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000303d40fb 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:649: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304e6ca4 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:22:18.398039 [ 4477 ] {} TCPHandler: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000303d40fb 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:649: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304e6ca4 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:22:19.357859 [ 6951 ] {0c8a767a-9ab7-48c5-994e-74adb1802cd3} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50840) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:19.441628 [ 6951 ] {} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7753: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3d9b1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:22.672670 [ 5971 ] {0549238f-b249-478e-a3d1-7f5b34303f37} executeQuery: Code: 6. DB::Exception: Cannot parse string ('') into vector of identifiers. (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 5, line 16) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Parsers/parseIdentifierOrStringLiteral.cpp:79: DB::parseIdentifiersOrStringLiterals(String const&, DB::Settings const&) @ 0x000000003307ed32 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:643: 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) @ 0x0000000030e2a578 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:22.686124 [ 5971 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string ('') into vector of identifiers. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Parsers/parseIdentifierOrStringLiteral.cpp:79: DB::parseIdentifiersOrStringLiterals(String const&, DB::Settings const&) @ 0x000000003307ed32 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:643: 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) @ 0x0000000030e2a578 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:22.817643 [ 5971 ] {261d07ab-9d0a-4f5e-a188-ab71bdd89648} executeQuery: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 6, line 17) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:22.835818 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:23.073651 [ 5971 ] {b2817373-16f7-4d6f-94d7-b612cdd1ddb5} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 7, line 18) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:23.076996 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:23.976907 [ 5971 ] {c670ae91-1e73-4862-931d-780e80c9a3c4} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 12, line 24) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_idx,d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.014182 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.143948 [ 5971 ] {ead1db62-9d09-4c43-b92f-8574bb5a4b39} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 13, line 25) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.148372 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.264241 [ 5971 ] {c0d69146-b7ca-4cd7-b74d-37b1408ee919} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 14, line 26) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_idx,,';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.279848 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.394798 [ 5971 ] {c6c3d9c5-2061-460c-9190-b631728ec493} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 15, line 27) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.400420 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.519998 [ 5971 ] {b1ecef7f-a28d-4314-9477-e34f17bad36b} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 16, line 28) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' `d1_null_idx`,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.532221 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.612592 [ 5971 ] {e9bb4271-db45-426d-b141-405ff4dc6a4f} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 17, line 29) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.619246 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.846725 [ 5971 ] {2ed93a44-e19f-4028-805a-f8fa5b5d97d4} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 18, line 30) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx ';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.850289 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.921257 [ 5971 ] {e50a91d9-c362-4757-8fe5-6d60c8dc8c0c} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 01515_force_data_skipping_indices.sql) (query 19, line 32) (in query: SELECT * FROM data_01515 WHERE d1_null = 0 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:24.937027 [ 5971 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: 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) @ 0x0000000030e2d889 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.042620 [ 4142 ] {01e10eab-d9a6-4495-b5a2-2a39b2cb0a55} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r2 (a0bab243-fe99-449f-93d0-f638a4262f19)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51114) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 5, line 8) (in query: DETACH TABLE r2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.077044 [ 4142 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r2 (a0bab243-fe99-449f-93d0-f638a4262f19)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.239142 [ 4938 ] {45171f88-d0ee-47fa-8fae-598eb233854f} executeQuery: Code: 57. DB::Exception: Table test_3.src already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51154) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: CREATE TABLE src (`p` UInt64, `k` String, `d` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/01034_move_partition_from_table_zookeeper_test_3/src3', '1') PARTITION BY p ORDER BY (p, k, d) SETTINGS index_granularity = 43824, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 116, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 161879556, compact_parts_max_granules_to_buffer = 29, compact_parts_merge_max_bytes_to_prefetch_part = 12509422, merge_max_block_size = 14354, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 7318811, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 75543, primary_key_compress_block_size = 43211, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.256902 [ 4938 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.src already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.548207 [ 4938 ] {3e8d62f3-55de-4a2f-952b-4eb332b7267a} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51180) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT * FROM numbers_mt(1000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d56 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.578119 [ 4938 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d56 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:22:26.829355 [ 3815 ] {4852246a-139e-415f-a4c7-682d82f150b4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43142) (comment: 03038_nested_dynamic_merges_small.gen.sql) (query 90, line 114) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:22:26.877649 [ 3815 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:27.724720 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:28.878127 [ 4938 ] {75f7638f-a03c-4cc9-aa1d-0e42dc916e08} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53908) (comment: 02478_window_frame_type_groups.sql) (query 1, line 1) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:28.942605 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:29.724390 [ 5971 ] {dcf6432b-a001-4d39-b21b-693d89f1a49d} executeQuery: Code: 36. DB::Exception: Table function numbers requires step to be a positive number. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53966) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:84: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a353b 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 7. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:22:29.739214 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:84: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a353b 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 7. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:22:30.303402 [ 4938 ] {cb87c23e-a567-47c1-a0ed-e83d5d131105} executeQuery: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54030) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:30.352970 [ 4938 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:31.238125 [ 5380 ] {57a380c2-cc65-4e05-97fc-8b161df96570} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51150) (comment: 02497_if_transform_strings_to_enum.sql) (query 30, line 40) (in query: SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c263b9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:22:31.246880 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c263b9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:22:31.430252 [ 5380 ] {e51424a1-a12a-4b3c-acc6-78ceec347ed9} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: While processing transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')): While processing SELECT transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51150) (comment: 02497_if_transform_strings_to_enum.sql) (query 31, line 41) (in query: EXPLAIN SYNTAX SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c263b9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb184e3 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 11. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 13. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a868c 14. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 15. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1596: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002d66592d 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2181: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002d66e12c 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x000000002dd2dca1 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: 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 @ 0x000000002dd1b73f 20. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: 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) @ 0x000000002dd11fe5 21. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:488: 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) @ 0x000000002dd0a046 22. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:305: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd09e33 23. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002dcc8086 24. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcc8724 25. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcc872f 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcc872f 27. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcbeb84 28. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcbc20c 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:22:31.442625 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:31.449361 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: While processing transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')): While processing SELECT transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c263b9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb184e3 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 11. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 13. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a868c 14. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 15. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1596: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002d66592d 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2181: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002d66e12c 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x000000002dd2dca1 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: 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 @ 0x000000002dd1b73f 20. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: 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) @ 0x000000002dd11fe5 21. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:488: 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) @ 0x000000002dd0a046 22. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:305: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd09e33 23. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002dcc8086 24. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcc8724 25. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcc872f 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcc872f 27. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcbeb84 28. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcbc20c 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:22:31.578956 [ 5380 ] {2a8b86c2-b7c7-45ce-b9c4-394c6ca1889e} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51150) (comment: 02497_if_transform_strings_to_enum.sql) (query 32, line 42) (in query: EXPLAIN QUERY TREE run_passes = 1 SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c263b9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 17. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:470: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcbf1af 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcbc20c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:22:31.617789 [ 5380 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c263b9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 17. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:470: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcbf1af 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcbc20c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:22:33.656298 [ 3885 ] {6aba8e1d-1080-4f23-8486-c73a0d2b6759} executeQuery: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54152) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:33.686589 [ 3885 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:33.847205 [ 5105 ] {f781d7ea-8c68-4945-a311-9b5e84d967c1} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 194.26 MiB (attempt to allocate chunk of 1.25 MiB), maximum: 9.31 GiB: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35738) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (query 1, line 1) (in query: SELECT sum(`__table2`.`value`) AS `sum(value)` FROM `test_11`.`test_parallel_replicas_automatic_left_side` AS `__table1` GLOBAL ALL INNER JOIN `_data_17534434633649129340_14632327048266609638` AS `__table2` USING (`number`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:221: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, long const&) @ 0x0000000023ac61c1 11. ./build_docker/./src/Columns/ColumnVector.cpp:998: DB::ColumnVector::createWithOffsets(DB::PODArray, 63ul, 64ul> const&, DB::ColumnConst const&, unsigned long, unsigned long) const @ 0x00000000300100fd 12. ./build_docker/./src/Columns/ColumnSparse.cpp:139: DB::ColumnSparse::convertToFullColumnIfSparse() const @ 0x000000002fd14548 13. ./build_docker/./src/Columns/ColumnSparse.cpp:901: DB::recursiveRemoveSparse(COW::immutable_ptr const&) @ 0x000000002fd20d10 14. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:456: DB::selectDispatchBlock(DB::HashJoin const&, unsigned long, std::vector> const&, DB::Block const&) @ 0x000000002db96f11 15. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:542: DB::ConcurrentHashJoin::dispatchBlock(std::vector> const&, DB::Block&&) @ 0x000000002db948ef 16. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:249: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002db934ae 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:22:33.892067 [ 5105 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 194.26 MiB (attempt to allocate chunk of 1.25 MiB), maximum: 9.31 GiB: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:221: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, long const&) @ 0x0000000023ac61c1 11. ./build_docker/./src/Columns/ColumnVector.cpp:998: DB::ColumnVector::createWithOffsets(DB::PODArray, 63ul, 64ul> const&, DB::ColumnConst const&, unsigned long, unsigned long) const @ 0x00000000300100fd 12. ./build_docker/./src/Columns/ColumnSparse.cpp:139: DB::ColumnSparse::convertToFullColumnIfSparse() const @ 0x000000002fd14548 13. ./build_docker/./src/Columns/ColumnSparse.cpp:901: DB::recursiveRemoveSparse(COW::immutable_ptr const&) @ 0x000000002fd20d10 14. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:456: DB::selectDispatchBlock(DB::HashJoin const&, unsigned long, std::vector> const&, DB::Block const&) @ 0x000000002db96f11 15. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:542: DB::ConcurrentHashJoin::dispatchBlock(std::vector> const&, DB::Block&&) @ 0x000000002db948ef 16. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:249: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002db934ae 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:34.071097 [ 2825 ] {02784_automatic_parallel_replicas_join-test_11_simple_join_0_pure} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Query memory tracker: fault injected. Would use 194.26 MiB (attempt to allocate chunk of 1.25 MiB), maximum: 9.31 GiB: While executing FillingRightJoinSide. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:221: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, long const&) @ 0x0000000023ac61c1 11. ./build_docker/./src/Columns/ColumnVector.cpp:998: DB::ColumnVector::createWithOffsets(DB::PODArray, 63ul, 64ul> const&, DB::ColumnConst const&, unsigned long, unsigned long) const @ 0x00000000300100fd 12. ./build_docker/./src/Columns/ColumnSparse.cpp:139: DB::ColumnSparse::convertToFullColumnIfSparse() const @ 0x000000002fd14548 13. ./build_docker/./src/Columns/ColumnSparse.cpp:901: DB::recursiveRemoveSparse(COW::immutable_ptr const&) @ 0x000000002fd20d10 14. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:456: DB::selectDispatchBlock(DB::HashJoin const&, unsigned long, std::vector> const&, DB::Block const&) @ 0x000000002db96f11 15. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:542: DB::ConcurrentHashJoin::dispatchBlock(std::vector> const&, DB::Block&&) @ 0x000000002db948ef 16. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:249: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002db934ae 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53936) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (query 1, line 1) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:22:34.073145 [ 5476 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33562, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:34.073788 [ 5476 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33562, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:34.098505 [ 2825 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Query memory tracker: fault injected. Would use 194.26 MiB (attempt to allocate chunk of 1.25 MiB), maximum: 9.31 GiB: While executing FillingRightJoinSide. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:221: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, long const&) @ 0x0000000023ac61c1 11. ./build_docker/./src/Columns/ColumnVector.cpp:998: DB::ColumnVector::createWithOffsets(DB::PODArray, 63ul, 64ul> const&, DB::ColumnConst const&, unsigned long, unsigned long) const @ 0x00000000300100fd 12. ./build_docker/./src/Columns/ColumnSparse.cpp:139: DB::ColumnSparse::convertToFullColumnIfSparse() const @ 0x000000002fd14548 13. ./build_docker/./src/Columns/ColumnSparse.cpp:901: DB::recursiveRemoveSparse(COW::immutable_ptr const&) @ 0x000000002fd20d10 14. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:456: DB::selectDispatchBlock(DB::HashJoin const&, unsigned long, std::vector> const&, DB::Block const&) @ 0x000000002db96f11 15. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:542: DB::ConcurrentHashJoin::dispatchBlock(std::vector> const&, DB::Block&&) @ 0x000000002db948ef 16. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:249: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002db934ae 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:34.256704 [ 4529 ] {c8cebe6f-fde0-4a6c-930f-132d78b85303} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:39240). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316adca3 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:35.623372 [ 4142 ] {02784_automatic_parallel_replicas_join-test_11_simple_join_10M_pure} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 53.95 MiB (attempt to allocate chunk of 1.13 MiB), maximum: 9.31 GiB: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54192) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (query 1, line 1) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399291f 9. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000002dbb2be0 10. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRefList, unsigned long, false, true, false>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, DB::ColumnVector>(DB::HashJoin&, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>&, std::vector> const&, std::vector> const&, DB::Block const*, DB::ColumnVector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002eafd712 11. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002eaef2c0 12. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: bool func_wrapper, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>)&, std::integral_constant>(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&&, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&) @ 0x000000002e477a19 13. ./base/base/../base/constexpr_helpers.h:24: bool static_for_impl, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int), 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19, 20, 21, 22, 23>(bool DB::joinDispatch, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int)&&, std::integer_sequence) @ 0x000000002e4751f0 14. ./base/base/../base/constexpr_helpers.h:31: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x000000002e45d00b 15. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:280: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002db93bb6 16. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:35.788871 [ 4142 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 53.95 MiB (attempt to allocate chunk of 1.13 MiB), maximum: 9.31 GiB: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399291f 9. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000002dbb2be0 10. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRefList, unsigned long, false, true, false>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, DB::ColumnVector>(DB::HashJoin&, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>&, std::vector> const&, std::vector> const&, DB::Block const*, DB::ColumnVector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002eafd712 11. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002eaef2c0 12. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: bool func_wrapper, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>)&, std::integral_constant>(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&&, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&) @ 0x000000002e477a19 13. ./base/base/../base/constexpr_helpers.h:24: bool static_for_impl, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int), 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19, 20, 21, 22, 23>(bool DB::joinDispatch, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int)&&, std::integer_sequence) @ 0x000000002e4751f0 14. ./base/base/../base/constexpr_helpers.h:31: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x000000002e45d00b 15. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:280: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002db93bb6 16. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:36.930790 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:36.933434 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:22:36.941842 [ 6951 ] {a6af87bc-2c43-476c-880e-e29cc821c7be} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54110) (comment: 01018_Distributed__shard_num.sql) (query 20, line 33) (in query: SELECT * FROM remote('127.0.0.1', system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:22:36.955429 [ 6951 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:37.247974 [ 3885 ] {02621ae1-c217-483d-9e5c-8d2ce2007036} executeQuery: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54288) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:37.255757 [ 3885 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:37.804143 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:40.463648 [ 3885 ] {1c38b386-8fe8-421f-b54f-35eac8d959f2} executeQuery: Code: 344. DB::Exception: Mutations are not supported for immutable disk '03008_local_plain_rewritable'. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41036) (comment: 03008_local_plain_rewritable.sh) (query 1, line 2) (in query: alter table 03008_test_local_mt update c = 0 where a % 2 = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3970: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030cdebfa 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cbd6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:40.485379 [ 3885 ] {} TCPHandler: Code: 344. DB::Exception: Mutations are not supported for immutable disk '03008_local_plain_rewritable'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3970: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030cdebfa 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cbd6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:40.614191 [ 4529 ] {49febd27-008c-41ef-83c5-70881d2e4a6c} executeQuery: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41060) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:40.636691 [ 4529 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:40.970510 [ 4529 ] {a5ac3f25-3fcb-47a8-94cb-d7cab9373b0f} executeQuery: Code: 497. DB::Exception: without_on_cluster_02250_ON_CLUSTER_grant_test_13: Not enough privileges. To execute this query, it's necessary to have the grant CLUSTER ON *.*. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41108) (comment: 02250_ON_CLUSTER_grant.sh) (query 1, line 1) (in query: CREATE DATABASE IF NOT EXISTS db_without_on_cluster_02250_ON_CLUSTER_grant_test_13 ON CLUSTER test_shard_localhost), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58dbc 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x000000002bd57fb1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd57518 7. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 8. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 9. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:114: DB::executeDDLQueryOnCluster(std::shared_ptr const&, std::shared_ptr, DB::DDLQueryOnClusterParams const&) @ 0x000000002e290fd4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2314: DB::InterpreterCreateQuery::executeQueryOnCluster(DB::ASTCreateQuery&) @ 0x000000002dc81b44 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2334: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94cea 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:40.984513 [ 4529 ] {} TCPHandler: Code: 497. DB::Exception: without_on_cluster_02250_ON_CLUSTER_grant_test_13: Not enough privileges. To execute this query, it's necessary to have the grant CLUSTER ON *.*. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58dbc 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x000000002bd57fb1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd57518 7. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 8. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 9. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:114: DB::executeDDLQueryOnCluster(std::shared_ptr const&, std::shared_ptr, DB::DDLQueryOnClusterParams const&) @ 0x000000002e290fd4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2314: DB::InterpreterCreateQuery::executeQueryOnCluster(DB::ASTCreateQuery&) @ 0x000000002dc81b44 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2334: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94cea 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:41.550548 [ 7056 ] {2ee79b94-d934-4474-9e3a-54c4b7ef3059} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54300) (comment: 03036_recursive_cte_postgres_2.sql) (query 14, line 93) (in query: -- extract all departments under 'A' with "level" number. -- Only shows level 2 or more WITH RECURSIVE subdepartment AS ( -- non recursive term SELECT 1 AS level, * FROM department WHERE name = 'A' UNION ALL -- recursive term SELECT sd.level + 1, d.* FROM department AS d, subdepartment AS sd WHERE d.parent_department = sd.id ) SELECT * FROM subdepartment WHERE level >= 2 ORDER BY name;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:41.616987 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:134: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003223524b 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x0000000032234fc2 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:41.725159 [ 5379 ] {e43a087f-1346-4c37-9a3c-140470b3b25b} 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.3.20372.altinityantalya (altinity build)) (from [::1]:41176) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./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&&) @ 0x00000000308c6fef 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:512: DB::StorageFileLog::openFilesAndSetPos() @ 0x00000000308b8b7b 6. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:135: DB::ReadFromStorageFileLog::makePipe() @ 0x00000000308c8032 7. ./build_docker/./src/Processors/QueryPlan/ReadFromStreamLikeEngine.cpp:36: DB::ReadFromStreamLikeEngine::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032252349 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:41.764051 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./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&&) @ 0x00000000308c6fef 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:512: DB::StorageFileLog::openFilesAndSetPos() @ 0x00000000308b8b7b 6. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:135: DB::ReadFromStorageFileLog::makePipe() @ 0x00000000308c8032 7. ./build_docker/./src/Processors/QueryPlan/ReadFromStreamLikeEngine.cpp:36: DB::ReadFromStreamLikeEngine::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000032252349 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:42.383024 [ 3816 ] {82fba938-bded-4fea-a791-ca3e1a4c094b} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41196) (comment: 00353_join_by_tuple.sql) (query 2, line 2) (in query: select a from (select (1, 2) as a) js1 any inner join (select (1, 2) as a) js2 using a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031df546f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031de6174 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031de68c1 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031df4614 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0e7a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0c8e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c3a4a09 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321327e9 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:42.387394 [ 3816 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031df546f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031de6174 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031de68c1 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031df4614 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0e7a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0c8e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c3a4a09 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321327e9 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:22:43.010815 [ 2827 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5603 similar messages) 2025.07.13 02:22:43.551469 [ 3816 ] {8b00a3e8-a9d0-482f-a28f-294251521ee8} executeQuery: Code: 36. DB::Exception: Unsupported value 2 of the `function_visible_width_behavior` setting: In scope SELECT visibleWidth('ClickHouse是一个很好的数æ®åº“') SETTINGS function_visible_width_behavior = 2. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41246) (comment: 02970_visible_width_behavior.sql) (query 4, line 4) (in query: SELECT visibleWidth('ClickHouse是一个很好的数æ®åº“') SETTINGS function_visible_width_behavior = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::FunctionVisibleWidth::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dabf81 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:22:43.560365 [ 3816 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported value 2 of the `function_visible_width_behavior` setting: In scope SELECT visibleWidth('ClickHouse是一个很好的数æ®åº“') SETTINGS function_visible_width_behavior = 2. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::FunctionVisibleWidth::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dabf81 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:22:43.581955 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:43.589562 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:22:44.074630 [ 4938 ] {c59da2e4-5a98-4294-86ae-8ae9747f4a17} executeQuery: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41304) (comment: 01034_move_partition_from_table_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE src MOVE PARTITION 1 TO TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:44.104861 [ 4938 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different ordering. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7761: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3da42 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:8729: DB::StorageReplicatedMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000306e3c51 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5641: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000030d0d322 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5720: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f247 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:45.514625 [ 6951 ] {ae0dc569-ff91-4b03-86e1-6963e21c6cc7} executeQuery: Code: 57. DB::Exception: Table test_1f1wikff.nested already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41152) (comment: 00625_arrays_in_nested.sql) (query 16, line 34) (in query: CREATE TABLE nested ( column Nested ( name String, names Array(String), types Array(Enum8('PU' = 1, 'US' = 2, 'OTHER' = 3)) ) ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:45.535840 [ 6951 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1f1wikff.nested already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:46.188668 [ 5380 ] {e106ef45-a15b-478e-8b61-bbbc45eda813} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:46.267005 [ 5380 ] {e106ef45-a15b-478e-8b61-bbbc45eda813} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41430) (comment: 01956_skip_unavailable_shards_excessive_attempts.sh) (query 1, line 1) (in query: select * from remote('255.255.255.255', system.one) settings use_hedged_requests=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000308540a5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028492e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284924c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:22:46.272960 [ 5380 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000308540a5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028492e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284924c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:22:47.089275 [ 6953 ] {ae5fa1f6-1d83-4613-aa14-b49b1342753d} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:47.592870 [ 2824 ] {473a75ec-2bd8-4cac-8ba0-b8c81912dddf} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:47.875030 [ 2824 ] {473a75ec-2bd8-4cac-8ba0-b8c81912dddf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41502) (comment: 01956_skip_unavailable_shards_excessive_attempts.sh) (query 1, line 1) (in query: select * from remote('255.255.255.255,127.2', system.one) settings use_hedged_requests=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:47.902624 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:48.222096 [ 5380 ] {8f3c6cb7-3b2d-4e2f-bded-11796f2fd4af} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41516) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 1) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_az2mbsvi' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%' SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:22:48.252286 [ 5380 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:22:49.034129 [ 10341 ] {bb60ea92-b525-4142-81d8-c7c883a6f1b0} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 24, line 33) (in query: SELECT val FROM tab WHERE now(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::NowOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fa7cb6d 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:49.046489 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::NowOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fa7cb6d 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:49.452451 [ 10341 ] {c83d5452-4fcf-4928-9a60-9ed50ca76dca} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now64(9, tz) != toDateTime64('2000-01-01 00:00:00', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 26, line 36) (in query: SELECT val FROM tab WHERE now64(9, tz) != toDateTime64('2000-01-01 00:00:00', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fa7ff12 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:49.462947 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE now64(9, tz) != toDateTime64('2000-01-01 00:00:00', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fa7ff12 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:49.770188 [ 4529 ] {5fb653c6-74f4-4a83-9ff1-967b94144456} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, 'pattern\\'_String :: 1) -> like(__table1.haystack, 'pattern\\'_String) UInt8 : 0'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33422) (comment: 02317_like_with_trailing_escape.sql) (query 4, line 7) (in query: -- const pattern SELECT haystack LIKE 'pattern\\' from tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x0000000023b21ddb 6. DB::MatchImpl::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001dc92b1b 7. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dc8e270 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:49.797279 [ 10341 ] {6183df5e-b2c6-47bc-b556-8e65fe213d54} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE nowInBlock(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 28, line 39) (in query: SELECT val FROM tab WHERE nowInBlock(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fa826cd 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:49.798114 [ 4529 ] {} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, 'pattern\\'_String :: 1) -> like(__table1.haystack, 'pattern\\'_String) UInt8 : 0'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x0000000023b21ddb 6. DB::MatchImpl::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001dc92b1b 7. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dc8e270 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:49.821023 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE nowInBlock(tz) != toDateTime('2000-01-01 00:00:00') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::FunctionNowInBlock::getReturnTypeImpl(std::vector> const&) const @ 0x000000001fa826cd 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:49.931641 [ 7056 ] {42d08fff-7390-4004-8fbd-2cc757962406} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: +, error: no argument for repetition operator: +. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('+', 'a+b+c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41488) (comment: 01866_split_by_regexp.sql) (query 12, line 13) (in query: select splitByRegexp('+', 'a+b+c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.033171 [ 7056 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: +, error: no argument for repetition operator: +. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('+', 'a+b+c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.107756 [ 4142 ] {e46ecc6c-26c4-4247-9dd2-857e5b2adbff} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:50.130294 [ 7056 ] {e6555b6d-d70b-476d-bda6-44e275fa20d3} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ?, error: no argument for repetition operator: ?. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('?', 'a?b?c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41488) (comment: 01866_split_by_regexp.sql) (query 13, line 14) (in query: select splitByRegexp('?', 'a?b?c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.132035 [ 4142 ] {e46ecc6c-26c4-4247-9dd2-857e5b2adbff} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33456) (comment: 01956_skip_unavailable_shards_excessive_attempts.sh) (query 1, line 1) (in query: select * from remote('255.255.255.255', system.one) settings use_hedged_requests=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000308540a5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028492e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284924c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.151554 [ 7056 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ?, error: no argument for repetition operator: ?. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('?', 'a?b?c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.152300 [ 4529 ] {5a83822b-5e6c-4669-8e52-06b9f632b245} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, __table1.pattern :: 0) -> like(__table1.haystack, __table1.pattern) UInt8 : 1'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33422) (comment: 02317_like_with_trailing_escape.sql) (query 5, line 10) (in query: -- non-const pattern SELECT haystack LIKE pattern from tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x0000000023b21ddb 6. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000001dc96b4e 7. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001dc96086 8. 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) @ 0x000000001dc91900 9. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dc8e100 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.153638 [ 4142 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000308540a5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028492e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284924c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.169528 [ 4529 ] {} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, __table1.pattern :: 0) -> like(__table1.haystack, __table1.pattern) UInt8 : 1'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x0000000023b21ddb 6. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000001dc96b4e 7. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001dc96086 8. 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) @ 0x000000001dc91900 9. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dc8e100 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.219504 [ 7056 ] {71c38fac-8364-4495-a714-dd92b3d6a014} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (, error: missing ): (. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('(', 'a(b(c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41488) (comment: 01866_split_by_regexp.sql) (query 14, line 15) (in query: select splitByRegexp('(', 'a(b(c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.224780 [ 7056 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (, error: missing ): (. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('(', 'a(b(c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.293008 [ 10341 ] {f750733d-7feb-44b5-8a62-99c9bf5b8865} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE toTimeZone(toDateTime(val), tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 30, line 42) (in query: SELECT val FROM tab WHERE toTimeZone(toDateTime(val), tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::ToTimeZoneOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020bfee92 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:50.317968 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE toTimeZone(toDateTime(val), tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::ToTimeZoneOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020bfee92 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:50.428517 [ 6915 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003117f00d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003117ef02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x0000000032823380 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x00000000328210b2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x000000003281ffaf 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003282d1fe 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:50.431371 [ 3185 ] {} test_7.clear_column2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.439837 [ 3189 ] {} test_1.t1_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.441129 [ 3248 ] {} test_3.deduplication (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.442234 [ 3218 ] {} test_az2mbsvi.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.443000 [ 3234 ] {} test_az2mbsvi.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.443730 [ 3252 ] {} test_1.t1_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.444566 [ 3262 ] {} test_7.clear_column1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.446348 [ 3177 ] {} test_11.table_rename_with_ttl (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.447031 [ 3245 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.448602 [ 3162 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:22:50.470164 [ 3232 ] {} test_15.data_r2 (9f5cb420-3210-41c8-ae0f-a46444c4b569): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:50.470236 [ 3254 ] {} test_15.data_r2 (9f5cb420-3210-41c8-ae0f-a46444c4b569): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/test_15/replicas/r2), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003063ff0f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:50.475244 [ 6122 ] {} DatabaseCatalog: Cannot drop table test_3.dst (873a7a9d-20cc-45a2-8674-14ab7e168c91). Will retry later.: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/01034_move_partition_from_table_zookeeper_test_3/dst3/replicas/1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af99c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af994d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:555: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x00000000327621f6 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1459: DB::StorageReplicatedMergeTree::dropReplica(std::shared_ptr, DB::TableZnodeInfo const&, std::shared_ptr, std::shared_ptr, std::optional*) @ 0x00000000305c1f5b 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1382: DB::StorageReplicatedMergeTree::drop() @ 0x00000000305be71a 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 12. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:50.536021 [ 7056 ] {cb9ad5d2-72fd-4b2d-bd9a-e16e69f33268} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: [, error: missing ]: [. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('[', 'a[b[c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41488) (comment: 01866_split_by_regexp.sql) (query 16, line 17) (in query: select splitByRegexp('[', 'a[b[c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.571467 [ 7056 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: [, error: missing ]: [. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('[', 'a[b[c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023abb574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020870feb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:22:50.705892 [ 10341 ] {97fc30f4-8dc6-45d8-a5df-b3c12932ab75} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Milli(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 32, line 45) (in query: SELECT val FROM tab WHERE fromUnixTimestamp64Milli(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017d11c79 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:50.723240 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Milli(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017d11c79 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:50.800420 [ 6873 ] {f0721604-5554-479c-9aba-fa7e140dab00} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:51.100729 [ 10341 ] {6ed47e07-a41c-403f-9fee-d73a98314ee8} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Micro(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 34, line 48) (in query: SELECT val FROM tab WHERE fromUnixTimestamp64Micro(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017d11c79 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:51.119282 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Micro(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017d11c79 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:51.416793 [ 3863 ] {fe3fae76-8325-4edd-9bba-f88165a80d53} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:51.421381 [ 10341 ] {cdb7cb41-e59d-4c78-b056-8d36e9878895} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Nano(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 36, line 51) (in query: SELECT val FROM tab WHERE fromUnixTimestamp64Nano(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017d11c79 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:51.437492 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE fromUnixTimestamp64Nano(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017d11c79 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:51.634797 [ 7213 ] {fe3fae76-8325-4edd-9bba-f88165a80d53} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:51.754311 [ 7056 ] {e5b079f2-c7e4-4255-84e5-15e26a700401} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function splitByRegexp must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41488) (comment: 01866_split_by_regexp.sql) (query 23, line 25) (in query: SELECT splitByRegexp(materialize(1), NULL, 3) -- { serverError ILLEGAL_COLUMN } ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc96eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:51.798284 [ 7056 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 0 for function splitByRegexp must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc96eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:51.895581 [ 10341 ] {55809e3c-b8fb-496c-be7f-5e0e3f8a3ca4} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime(val, tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 38, line 54) (in query: SELECT val FROM tab WHERE snowflakeToDateTime(val, tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085b1d3 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:51.916036 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime(val, tz) != toDateTime('2023-06-11 14:14:14') ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085b1d3 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:52.231409 [ 10341 ] {18225b36-14b1-4874-826a-6ac572370753} executeQuery: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime64(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 40, line 57) (in query: SELECT val FROM tab WHERE snowflakeToDateTime64(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val SETTINGS allow_nonconst_timezone_arguments = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085c5d3 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:52.238916 [ 10341 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column tz of time zone argument of function, must be a constant string: In scope SELECT val FROM tab WHERE snowflakeToDateTime64(val, tz) != toDateTime64('2023-06-11 14:14:14', 6) ORDER BY val ASC SETTINGS allow_nonconst_timezone_arguments = 0. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x000000002b375bfe 6. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x000000002b375e6c 7. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085c5d3 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:22:52.842003 [ 10341 ] {ee4ba6be-2698-41ff-9be3-acd882d0a6ab} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41192) (comment: 00515_enhanced_time_zones.sql) (query 44, line 66) (in query: CREATE TABLE tab (`country` LowCardinality(FixedString(7)) DEFAULT 'unknown', `city` LowCardinality(String) DEFAULT 'unknown', `region` LowCardinality(String) DEFAULT 'unknown', `continent` LowCardinality(FixedString(7)) DEFAULT 'unknown', `is_eu_country` Bool, `date` DateTime CODEC(DoubleDelta, LZ4), `viewer_date` DateTime ALIAS toTimezone(date, timezone), `device_browser` LowCardinality(String) DEFAULT 'unknown', `metro_code` LowCardinality(String) DEFAULT 'unknown', `domain` String DEFAULT 'unknown', `device_platform` LowCardinality(String) DEFAULT 'unknown', `device_type` LowCardinality(String) DEFAULT 'unknown', `device_vendor` LowCardinality(String) DEFAULT 'unknown', `ip` FixedString(39) DEFAULT 'unknown', `lat` Decimal(8, 6) CODEC(T64), `lng` Decimal(9, 6) CODEC(T64), `asset_id` String DEFAULT 'unknown', `is_personalized` Bool, `metric` String, `origin` String DEFAULT 'unknown', `product_id` UInt64 CODEC(T64), `referer` String DEFAULT 'unknown', `server_side` Int8 CODEC(T64), `third_party_id` String DEFAULT 'unknown', `partner_slug` LowCardinality(FixedString(10)) DEFAULT 'unknown', `user_agent` String DEFAULT 'unknown', `user_id` UUID, `zip` FixedString(10) DEFAULT 'unknown', `timezone` LowCardinality(String), `as_organization` LowCardinality(String) DEFAULT 'unknown', `content_cat` Array(String), `playback_method` LowCardinality(String) DEFAULT 'unknown', `store_id` LowCardinality(String) DEFAULT 'unknown', `store_url` String DEFAULT 'unknown', `timestamp` Nullable(DateTime), `ad_count` Int8 CODEC(T64), `ad_type` LowCardinality(FixedString(10)) DEFAULT 'unknown', `ad_categories` Array(FixedString(8)), `blocked_ad_categories` Array(FixedString(8)), `break_max_ad_length` Int8 CODEC(T64), `break_max_ads` Int8 CODEC(T64), `break_max_duration` Int8 CODEC(T64), `break_min_ad_length` Int8 CODEC(T64), `break_position` LowCardinality(FixedString(18)) DEFAULT 'unknown', `media_playhead` String DEFAULT 'unknown', `placement_type` Int8 CODEC(T64), `transaction_id` String, `universal_ad_id` Array(String), `client_ua` LowCardinality(String) DEFAULT 'unknown', `device_ip` FixedString(39) DEFAULT 'unknown', `device_ua` LowCardinality(String) DEFAULT 'unknown', `ifa` String, `ifa_type` LowCardinality(String) DEFAULT 'unknown', `vast_lat` Decimal(8, 6) CODEC(T64), `vast_long` Decimal(9, 6) CODEC(T64), `server_ua` String DEFAULT 'unknown', `app_bundle` String DEFAULT 'unknown', `page_url` String DEFAULT 'unknown', `api_framework` Array(UInt8), `click_type` LowCardinality(String), `extensions` Array(String), `media_mime` Array(String), `om_id_partner` LowCardinality(String) DEFAULT 'unknown', `player_capabilities` Array(FixedString(12)), `vast_versions` Array(UInt8), `verification_vendors` Array(String), `ad_play_head` String DEFAULT 'unknown', `ad_serving_id` String DEFAULT 'unknown', `asset_uri` String DEFAULT 'unknown', `content_id` String DEFAULT 'unknown', `content_uri` String DEFAULT 'unknown', `inventory_state` Array(FixedString(14)), `player_size` Array(UInt8), `player_state` Array(FixedString(12)), `pod_sequence` Int8 CODEC(T64), `click_position` Array(UInt32), `error_code` Int16 CODEC(T64), `error_reason` Int8 CODEC(T64), `gdpr_consent` String DEFAULT 'unknown', `limited_tracking` Bool, `regulations` String DEFAULT 'unknown', `content_category` Array(String), PROJECTION projection_TPAG_VAST_date (SELECT * ORDER BY toYYYYMMDD(date), metric, product_id, asset_id)) ENGINE = MergeTree ORDER BY (product_id, metric, asset_id, toYYYYMMDD(date)) SETTINGS index_granularity = 49898, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 170442607, compact_parts_max_granules_to_buffer = 160, compact_parts_merge_max_bytes_to_prefetch_part = 33362410, merge_max_block_size = 23099, old_parts_lifetime = 10., 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 = 6497732019, index_granularity_bytes = 5639402, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 14, 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 = 28561, primary_key_compress_block_size = 74607, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:52.848694 [ 10341 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:22:53.363882 [ 4694 ] {d08a368e-f003-472a-b843-9b6263dc8c7b} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 132.25 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:51702) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (query 1, line 1) (in query: SELECT sum(`__table2`.`value`) AS `sum(value)` FROM `test_11`.`test_parallel_replicas_automatic_left_side` AS `__table1` GLOBAL ALL INNER JOIN `_data_17534434633649129340_14632327048266609638` AS `__table2` USING (`number`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:22:53.380268 [ 4694 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 132.25 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:53.395659 [ 4938 ] {02784_automatic_parallel_replicas_join-test_11_simple_join_1M_pure} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Query memory tracker: fault injected. Would use 132.25 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41382) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (query 1, line 1) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:22:53.429088 [ 4938 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Query memory tracker: fault injected. Would use 132.25 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:22:54.036134 [ 5380 ] {02784_automatic_parallel_replicas_join-test_11_simple_join_300k_pure} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x00000000239925e1 9. ./src/Common/HashTable/HashTable.h:491: TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>* std::construct_at[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*>(TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*) @ 0x000000002e4fe86f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>>::__shared_ptr_emplace[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>) @ 0x000000002e4fe6fb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x000000002e4fe579 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x000000002e4f8124 13. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x000000002e455ae6 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x000000002e45268a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002dbab911 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 4. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 11. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 13. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:54.065732 [ 5380 ] {02784_automatic_parallel_replicas_join-test_11_simple_join_300k_pure} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33694) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (query 1, line 1) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x00000000239925e1 9. ./src/Common/HashTable/HashTable.h:491: TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>* std::construct_at[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*>(TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*) @ 0x000000002e4fe86f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>>::__shared_ptr_emplace[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>) @ 0x000000002e4fe6fb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x000000002e4fe579 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x000000002e4f8124 13. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x000000002e455ae6 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x000000002e45268a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002dbab911 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:22:54.102473 [ 5380 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x00000000239925e1 9. ./src/Common/HashTable/HashTable.h:491: TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>* std::construct_at[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*>(TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*) @ 0x000000002e4fe86f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>>::__shared_ptr_emplace[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>) @ 0x000000002e4fe6fb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x000000002e4fe579 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x000000002e4f8124 13. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x000000002e455ae6 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x000000002e45268a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002dbab911 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 4. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 11. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 13. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:22:57.705922 [ 5105 ] {8fb68e85-bfb6-4173-89ca-078dc63e9f40} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42286) (comment: 02125_query_views_log.sql) (in query: DROP DATABASE IF EXISTS test_ypkecevu SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:22:57.707806 [ 5105 ] {8fb68e85-bfb6-4173-89ca-078dc63e9f40} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:57.915545 [ 4529 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:58.174009 [ 6024 ] {7d46b0ff-ab80-44c2-b92d-c479ce17ab0f} 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.3.20372.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33934) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (query 2, line 4) (in query: select * from file('02268_data.jsonl');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303df7fa 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303e0f46 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303e1797 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cae74 15. ./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 @ 0x00000000284c8039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cd40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:22:58.214087 [ 6024 ] {} 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.3.20372.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303df7fa 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303e0f46 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303e1797 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cae74 15. ./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 @ 0x00000000284c8039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cd40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:22:58.498368 [ 6024 ] {b32a9c07-9b61-4626-a4db-afb2263d1e4f} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33934) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (query 4, line 7) (in query: select * from file('02268_data.jsonCompactEachRow');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303df7fa 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303e0f46 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303e1797 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cae74 15. ./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 @ 0x00000000284c8039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cd40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:22:58.523432 [ 6024 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303df7fa 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303e0f46 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303e1797 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cae74 15. ./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 @ 0x00000000284c8039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cd40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:22:59.074536 [ 2824 ] {15678ade-d087-4e2d-8ab2-3db40988c4ba} executeQuery: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54034) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 1, line 1) (in query: select toDateTime(0, '/abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.107277 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.162708 [ 2824 ] {14292549-b5cb-489b-b887-44958c934444} executeQuery: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54034) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 2, line 2) (in query: select toDateTime(0, './abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.175377 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.266821 [ 2824 ] {9873fc32-796b-4737-80ad-543f7a288105} executeQuery: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54034) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 3, line 3) (in query: select toDateTime(0, '../abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.303126 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.352458 [ 2824 ] {222ebe27-11ee-4457-a9d2-0a76014ad28d} executeQuery: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54034) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 4, line 4) (in query: select toDateTime(0, '~/abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.385211 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.468804 [ 2824 ] {054e8a9e-2da1-4edc-b33e-d73b4d70df6f} executeQuery: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54034) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 5, line 5) (in query: select toDateTime(0, 'abc/../../cba');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.485492 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c40fef9 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3c379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3c180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b03a2a5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b039d47 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:22:59.843654 [ 2825 ] {1dbd6f2d-ce51-4b69-97dd-abcbb202c10a} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33744) (comment: 00203_full_join.sql) (query 22, line 29) (in query: SELECT k1, k2, k3, val_t1, val_t2 FROM t1_00203 ANY FULL JOIN t2_00203 USING (k3, k1, k2) ORDER BY k1, k2, k3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:997: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbb77b1 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbac8dc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:22:59.850415 [ 2825 ] {} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:997: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbb77b1 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbac8dc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:23:04.196309 [ 2824 ] {0a08405b-c5bd-4596-bee9-2545d1316eaf} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 3, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 6, line 11) (in query: select multiFuzzyMatchAny('abc', 3, ['a1c']) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:23:04.226025 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 3, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:23:04.332103 [ 2824 ] {7fd17033-26df-49e9-88dd-771710822965} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 4, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 7, line 12) (in query: select multiFuzzyMatchAny('abc', 4, ['a1c']) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:23:04.340883 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 4, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:23:04.503317 [ 4529 ] {2ccc4547-23c3-4f9c-9670-4303a99e2766} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54350) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (query 1, line 1) (in query: CREATE TABLE dst_r1 (`p` UInt64, `k` String, `d` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/02864_replace_partition_with_duplicated_parts_zookeeper_test_h02kttl3/dst_1', '1') PARTITION BY p ORDER BY k SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 1, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 1022, min_bytes_for_wide_part = 19192687, 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 = 281802883, compact_parts_max_bytes_to_buffer = 83347837, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 12082235, merge_max_block_size = 13031, prefer_fetch_merged_part_size_threshold = 6815813884, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6525657814, index_granularity_bytes = 18990353, 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 = false, marks_compress_block_size = 75240, primary_key_compress_block_size = 69704, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:04.528330 [ 4529 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:04.551590 [ 5105 ] {2a51d3f7-0411-4a57-a80f-fb6f7faf9a8c} executeQuery: Code: 57. DB::Exception: Table test_6e0d7shv.csv already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54360) (comment: 00301_csv.sh) (query 1, line 1) (in query: CREATE TABLE csv (t DateTime('Asia/Istanbul'), s String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:04.570475 [ 5105 ] {} TCPHandler: Code: 57. DB::Exception: Table test_6e0d7shv.csv already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:04.960162 [ 7056 ] {c014895d-bd0b-4406-b8a1-4a9a947fda5b} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54384) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (query 1, line 1) (in query: CREATE TABLE dst_r2 (`p` UInt64, `k` String, `d` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/02864_replace_partition_with_duplicated_parts_zookeeper_test_h02kttl3/dst_1', '2') PARTITION BY p ORDER BY k SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 1, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 1022, min_bytes_for_wide_part = 19192687, 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 = 281802883, compact_parts_max_bytes_to_buffer = 83347837, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 12082235, merge_max_block_size = 13031, prefer_fetch_merged_part_size_threshold = 6815813884, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6525657814, index_granularity_bytes = 18990353, 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 = false, marks_compress_block_size = 75240, primary_key_compress_block_size = 69704, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:04.968150 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:05.795542 [ 2824 ] {fd9dff87-efa8-49be-aece-623d90578eca} executeQuery: Code: 36. DB::Exception: Pattern '^hello.*world$' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('hello some world', 10, ['^hello.*world$']). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 15, line 22) (in query: select multiFuzzyMatchAny('hello some world', 10, ['^hello.*world$']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:23:05.799606 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Pattern '^hello.*world$' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('hello some world', 10, ['^hello.*world$']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:23:05.901897 [ 7056 ] {5e714927-7229-44e9-9f48-2db6a72756ca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54400) (comment: 00148_summing_merge_tree_aggregate_function.sql) (query 5, line 12) (in query: insert into summing_merge_tree_aggregate_function select today() as d, number as k, uniqState(toUInt64(number % 500)) from numbers(5000) group by d, k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:05.902274 [ 2824 ] {2b1cb09b-c132-48b6-8ccb-812dd5a069df} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny('hello some world', -1, ['^hello.*world$']). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 16, line 23) (in query: select multiFuzzyMatchAny('hello some world', -1, ['^hello.*world$']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringFuzzySearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f00ec7d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:23:05.934787 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:23:05.935026 [ 2824 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny('hello some world', -1, ['^hello.*world$']). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringFuzzySearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f00ec7d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:23:06.081265 [ 2824 ] {1ff66dab-684a-4556-a1e4-12608cb0c7d4} executeQuery: Code: 44. DB::Exception: Illegal column Const(UInt64). The number is not const or does not fit in UInt32: In scope SELECT multiFuzzyMatchAny('hello some world', 10000000000, ['^hello.*world$']). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 17, line 24) (in query: select multiFuzzyMatchAny('hello some world', 10000000000, ['^hello.*world$']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00e307 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:23:06.095588 [ 2824 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Const(UInt64). The number is not const or does not fit in UInt32: In scope SELECT multiFuzzyMatchAny('hello some world', 10000000000, ['^hello.*world$']). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00e307 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:23:06.118601 [ 4142 ] {156c7bff-d5f8-4d73-9183-d3dc6ceb2141} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39308) (comment: 00148_summing_merge_tree_aggregate_function.sql) (in query: DROP DATABASE IF EXISTS test_02m6nz0s SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:23:06.125237 [ 4142 ] {156c7bff-d5f8-4d73-9183-d3dc6ceb2141} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:07.497075 [ 5379 ] {227f3748-eb4f-43e3-a0cd-9077169d8d56} executeQuery: Code: 60. DB::Exception: Table test_h02kttl3.dst_r1 does not exist. Maybe you meant test_15.data_r1?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54568) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE dst_r1 REPLACE PARTITION 1 FROM src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:23:07.549822 [ 5379 ] {} TCPHandler: Code: 60. DB::Exception: Table test_h02kttl3.dst_r1 does not exist. Maybe you meant test_15.data_r1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:23:08.091053 [ 3885 ] {275bb8e9-6cc6-46c0-bdcc-dbed8ff0f44c} executeQuery: Code: 60. DB::Exception: Table test_h02kttl3.dst_r2 does not exist. Maybe you meant test_15.data_r2?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54610) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA dst_r2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000002e30bbbb 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7e97 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:08.113719 [ 3885 ] {} TCPHandler: Code: 60. DB::Exception: Table test_h02kttl3.dst_r2 does not exist. Maybe you meant test_15.data_r2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000002e30bbbb 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7e97 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:08.308379 [ 2825 ] {695b0fa8-3b78-4659-b7e6-07564ef70bdb} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54546) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x0000000023e8a3ef 5. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c6b83fc 6. 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&) @ 0x000000002ad7a243 7. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 8. 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 @ 0x000000002ad7af85 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002ad7aae2 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:23:08.401583 [ 2825 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x0000000023e8a3ef 5. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c6b83fc 6. 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&) @ 0x000000002ad7a243 7. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 8. 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 @ 0x000000002ad7af85 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002ad7aae2 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:23:08.466229 [ 4142 ] {04072723-51cd-4ef5-b9c6-6c5ef45167e3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54634) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (query 1, line 1) (in query: SELECT count(), sum(d) FROM dst_r1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:23:08.586529 [ 4142 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r1' in scope SELECT count(), sum(d) FROM dst_r1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:23:08.855709 [ 6024 ] {d11a5042-0f38-48eb-91e2-d32a32cf133e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46466) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (query 1, line 1) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:23:08.871413 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dst_r2' in scope SELECT count(), sum(d) FROM dst_r2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:23:09.449275 [ 2824 ] {600d543f-c948-4605-b90c-dbd10f0998a4} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 3_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 3_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 30, line 40) (in query: select multiFuzzyMatchAny(materialize('abc'), 3, materialize(['a1c'])) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:23:09.454002 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 3_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 3_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:09.574835 [ 2824 ] {785988fb-afd2-4906-aade-424f74c52fbb} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 4_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 4_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 31, line 41) (in query: select multiFuzzyMatchAny(materialize('abc'), 4, materialize(['a1c'])) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:23:09.600840 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 4_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 4_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:10.200974 [ 7056 ] {32f0474d-9f2a-4b1b-b22f-c910663af70b} executeQuery: Code: 57. DB::Exception: Table test_6e0d7shv.csv already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46574) (comment: 00301_csv.sh) (query 1, line 1) (in query: CREATE TABLE csv (f1 String, f2 UInt64, f3 UInt256, f4 UInt64 Default 33, f5 Nullable(UInt64), f6 Nullable(UInt64) Default 55, f7 String DEFAULT 'Default') ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:10.236285 [ 7056 ] {} TCPHandler: Code: 57. DB::Exception: Table test_6e0d7shv.csv already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.066370 [ 2824 ] {2cf565a4-8cc4-4769-afcf-34180d358e0d} executeQuery: Code: 36. DB::Exception: Pattern '^hello.*world$' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('hello some world'_String) :: 4, 10_UInt8 :: 2, materialize(_CAST(['^hello.*world$']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('hello some world'_String), 10_UInt8, materialize(_CAST(['^hello.*world$']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 39, line 51) (in query: select multiFuzzyMatchAny(materialize('hello some world'), 10, materialize(['^hello.*world$']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.078650 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Pattern '^hello.*world$' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('hello some world'_String) :: 4, 10_UInt8 :: 2, materialize(_CAST(['^hello.*world$']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('hello some world'_String), 10_UInt8, materialize(_CAST(['^hello.*world$']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x000000001f0103ee 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x000000001f006d5a 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00ce11 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.138435 [ 4938 ] {4572ed93-ca92-4c1b-9cbe-ab06bebb5412} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `f1` in scope SELECT * FROM csv ORDER BY f1 ASC, f2 ASC, f3 ASC, f4 ASC, f5 ASC NULLS FIRST, f6 ASC, f7 ASC. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 00301_csv.sh) (query 1, line 1) (in query: SELECT * FROM csv ORDER BY f1, f2, f3, f4, f5 NULLS FIRST, f6, f7), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4022: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc507d0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc056cc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.159218 [ 4938 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `f1` in scope SELECT * FROM csv ORDER BY f1 ASC, f2 ASC, f3 ASC, f4 ASC, f5 ASC NULLS FIRST, f6 ASC, f7 ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4022: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc507d0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc056cc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.210998 [ 2824 ] {af0c0bd3-97ae-4dd6-8253-4ddf0efe4761} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny(materialize('hello some world'), -1, materialize(['^hello.*world$'])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 40, line 52) (in query: select multiFuzzyMatchAny(materialize('hello some world'), -1, materialize(['^hello.*world$']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringFuzzySearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f00ec7d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.218491 [ 2824 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny(materialize('hello some world'), -1, materialize(['^hello.*world$'])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringFuzzySearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f00ec7d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.469858 [ 2824 ] {5b0d3a80-e966-4c3b-9ad1-e27fb3f18ba0} executeQuery: Code: 44. DB::Exception: Illegal column Const(UInt64). The number is not const or does not fit in UInt32. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54256) (comment: 00929_multi_match_edit_distance.sql) (query 41, line 53) (in query: select multiFuzzyMatchAny(materialize('hello some world'), 10000000000, materialize(['^hello.*world$']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00e307 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:11.475708 [ 2824 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Const(UInt64). The number is not const or does not fit in UInt32. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00e307 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:12.726035 [ 4938 ] {b040a6c0-0b8c-40c3-a089-534637f16240} executeQuery: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46690) (comment: 01459_default_value_of_argument_type_nullptr_dereference.sql) (query 1, line 1) (in query: SELECT defaultValueOfTypeName(FQDN());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a064c40 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:23:12.740013 [ 4938 ] {} TCPHandler: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a064c40 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:23:12.963279 [ 6024 ] {58057c8a-dbc9-4cb4-8197-00160e73b24e} executeQuery: Code: 117. DB::Exception: Incorrect name for a database. It shouldn't be empty: In scope SELECT getMaxTableNameLengthForDatabase(''). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46674) (comment: 03253_getMaxTableNameLength.sql) (query 3, line 3) (in query: SELECT getMaxTableNameLengthForDatabase('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionGetMaxTableNameLengthForDatabase::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afb827d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:23:12.970311 [ 6024 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect name for a database. It shouldn't be empty: In scope SELECT getMaxTableNameLengthForDatabase(''). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionGetMaxTableNameLengthForDatabase::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afb827d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:23:13.866259 [ 3665 ] {1c4be499-6abf-445a-a2c0-c4f7551f8160} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 'string1').). 2025.07.13 02:23:14.598759 [ 5105 ] {58611884-09fb-403e-8335-048d36fc2154} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46762) (comment: 02597_column_update_and_replication.sql) (query 1, line 4) (in query: CREATE TABLE test (`c_id` String, `p_id` String, `d` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/test_table', '1') ORDER BY (c_id, p_id) SETTINGS index_granularity = 17043, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 109, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 283081182, compact_parts_max_granules_to_buffer = 56, compact_parts_merge_max_bytes_to_prefetch_part = 20490875, merge_max_block_size = 10414, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 429769, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 719304246, index_granularity_bytes = 28525537, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 98, 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 = 99121, primary_key_compress_block_size = 99087, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:14.631829 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.301458 [ 4694 ] {2fe8edc0-b671-48c6-9206-23c2eaa712ac} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46876) (comment: 02317_functions_with_nothing.sql) (query 1, line 1) (in query: SELECT JSONExtractKeysAndValuesRaw(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.314138 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.403302 [ 4694 ] {0779d0b1-e6e5-4e5d-8db2-bc62afde7109} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46876) (comment: 02317_functions_with_nothing.sql) (query 2, line 2) (in query: SELECT JSONHas(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.410138 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.495260 [ 4694 ] {807eb90e-d8c2-479e-96c2-49c3abb69a4c} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46876) (comment: 02317_functions_with_nothing.sql) (query 3, line 3) (in query: SELECT isValidJSON(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.519362 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.637827 [ 4694 ] {14347dc9-3d2b-43b6-b7e3-2879d4faef94} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46876) (comment: 02317_functions_with_nothing.sql) (query 4, line 4) (in query: SELECT concat(arrayJoin([]), arrayJoin([NULL, '']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.651377 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.741136 [ 4694 ] {ac1ca8ce-439f-48de-8ec6-8e7efd9b4e23} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46876) (comment: 02317_functions_with_nothing.sql) (query 5, line 5) (in query: SELECT plus(arrayJoin([]), arrayJoin([NULL, 1]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.753005 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.817205 [ 4694 ] {2431ed75-3927-4819-a491-41e42fdd7f27} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46876) (comment: 02317_functions_with_nothing.sql) (query 6, line 6) (in query: SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:16.835017 [ 4694 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:23:18.303934 [ 6942 ] {5e30d772-9d56-4b23-b3e1-a038765fef6b} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 'string1').). 2025.07.13 02:23:18.455408 [ 4529 ] {779657ee-6772-467f-a39a-e230078f82af} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_7` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-04-06 00:36:21. Name of quota template: `quota_by_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48650) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:18.459076 [ 4529 ] {779657ee-6772-467f-a39a-e230078f82af} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_7` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-04-06 00:36:21. Name of quota template: `quota_by_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:18.487996 [ 4529 ] {779657ee-6772-467f-a39a-e230078f82af} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:48650). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. ./src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x00000000317068c3 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:145: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003170145e 7. DB::WriteBuffer::next() @ 0x0000000017cd6383 8. ./src/IO/WriteBuffer.h:127: DB::HTTPWriteBuffer::finalizeImpl() @ 0x0000000031706223 9. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:217: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x0000000031702777 10. ./build_docker/./src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x0000000023b67a57 11. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:282: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003170384f 12. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000315c3822 13. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c7c3e 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:18.560027 [ 4938 ] {b2f5099a-ef54-4530-976a-4b83f5ac3e85} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_7` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-04-06 00:36:21. Name of quota template: `quota_by_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48660) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:18.561982 [ 4938 ] {b2f5099a-ef54-4530-976a-4b83f5ac3e85} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_7` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-04-06 00:36:21. Name of quota template: `quota_by_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:18.650132 [ 5379 ] {1e8f352c-6368-4361-a926-ee3541b9dff4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51590) (comment: 01043_dictionary_attribute_properties_values.sql) (in query: DROP DATABASE IF EXISTS test_qcpqxe32 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:23:18.657340 [ 5379 ] {1e8f352c-6368-4361-a926-ee3541b9dff4} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:18.675020 [ 2825 ] {d82566ba-69cb-41fb-84dd-efa207e9d2ea} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_7` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-04-06 00:36:21. Name of quota template: `quota_by_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48666) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:18.676592 [ 2825 ] {d82566ba-69cb-41fb-84dd-efa207e9d2ea} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_7` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-04-06 00:36:21. Name of quota template: `quota_by_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:19.032551 [ 5072 ] {f5a28b97-e479-46b1-b340-e7ccf8b30793} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri http://localhost:11111/test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing URL. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56508) (comment: 02270_errors_in_files_s3.sh) (query 1, line 1) (in query: SELECT __table1.c1 AS c1, __table1.c2 AS c2, __table1.c3 AS c3 FROM url('http://localhost:11111/test/{a,tsv_with_header}.tsv', 'TSV', 'c1 UInt64, c2 UInt64, c3 UInt64') AS __table1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x00000000307f2d20 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:23:19.052593 [ 5379 ] {f90024c4-275f-47fd-8fe1-6575dc5b2d4a} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-03-27 11:51:38. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42878) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:19.054123 [ 5072 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri http://localhost:11111/test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing URL. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x00000000307f2d20 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:19.057387 [ 5105 ] {b087b591-9733-434d-8ee3-9c0c1cd959aa} executeQuery: Code: 27. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri http://localhost:11111/test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing URL. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x00000000307f2d20 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47012) (comment: 02270_errors_in_files_s3.sh) (query 1, line 1) (in query: SELECT * FROM url('http://localhost:11111/test/{a,tsv_with_header}.tsv', 'TSV', 'c1 UInt64, c2 UInt64, c3 UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:23:19.088285 [ 5379 ] {f90024c4-275f-47fd-8fe1-6575dc5b2d4a} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-03-27 11:51:38. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:19.089057 [ 5105 ] {} TCPHandler: Code: 27. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri http://localhost:11111/test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing URL. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x00000000307f2d20 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:19.091332 [ 5105 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:47012, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:19.092113 [ 5105 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:47012, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:19.093013 [ 5379 ] {f90024c4-275f-47fd-8fe1-6575dc5b2d4a} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42878). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. ./src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x00000000317068c3 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:145: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003170145e 7. DB::WriteBuffer::next() @ 0x0000000017cd6383 8. ./src/IO/WriteBuffer.h:127: DB::HTTPWriteBuffer::finalizeImpl() @ 0x0000000031706223 9. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:217: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x0000000031702777 10. ./build_docker/./src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x0000000023b67a57 11. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:282: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003170384f 12. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000315c3822 13. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c7c3e 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:19.287258 [ 5105 ] {596911ec-42c8-4ce9-abf4-b0cfc88da463} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-03-27 11:51:38. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42898) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:19.290031 [ 5105 ] {596911ec-42c8-4ce9-abf4-b0cfc88da463} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-03-27 11:51:38. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:19.876329 [ 5105 ] {2f38dfbe-73a2-4cc7-b9f9-71db2ecb219d} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-03-03 04:04:58. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42928) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:19.881500 [ 5105 ] {2f38dfbe-73a2-4cc7-b9f9-71db2ecb219d} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-03-03 04:04:58. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:20.051980 [ 6126 ] {ca783402-c9b2-404f-8884-25289facaf25} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing S3(_table_function.s3Cluster)Source. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43170) (comment: 02270_errors_in_files_s3.sh) (query 1, line 1) (in query: SELECT __table1.c1 AS c1, __table1.c2 AS c2, __table1.c3 AS c3 FROM s3Cluster('parallel_replicas', 'http://localhost:11111/test/{a,tsv_with_header}.tsv', 'TSV', 'c1 UInt64, c2 UInt64, c3 UInt64') AS __table1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:266: DB::StorageObjectStorageSource::generate() @ 0x000000002b5a1e35 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.078535 [ 4938 ] {90d53ba0-13ba-41de-b305-96e04bbc6ccb} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-03-03 04:04:58. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42944) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.092762 [ 4938 ] {90d53ba0-13ba-41de-b305-96e04bbc6ccb} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-03-03 04:04:58. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:20.097290 [ 6126 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing S3(_table_function.s3Cluster)Source. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:266: DB::StorageObjectStorageSource::generate() @ 0x000000002b5a1e35 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.162168 [ 3863 ] {f35a2915-c115-46dc-9757-36c65c820a39} executeQuery: Code: 27. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing S3(_table_function.s3Cluster)Source. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:266: DB::StorageObjectStorageSource::generate() @ 0x000000002b5a1e35 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59188) (comment: 02270_errors_in_files_s3.sh) (query 1, line 1) (in query: SELECT * FROM s3('http://localhost:11111/test/{a,tsv_with_header}.tsv', 'TSV', 'c1 UInt64, c2 UInt64, c3 UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:23:20.196242 [ 3863 ] {} TCPHandler: Code: 27. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing S3(_table_function.s3Cluster)Source. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000031d1ec97 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a0ef 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 15. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:266: DB::StorageObjectStorageSource::generate() @ 0x000000002b5a1e35 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.199003 [ 3863 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:59188, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:20.201472 [ 3863 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:59188, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:20.350319 [ 2824 ] {287bf95a-1d43-444f-b848-94321c87ab48} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46938) (comment: 01361_buffer_table_flush_with_materialized_view.sql) (query 17, line 37) (in query: DROP TABLE IF EXISTS b1_01361;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.351707 [ 4142 ] {24828a9d-9bc9-437f-bb38-8a1ba068a7e1} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-03-03 04:04:58. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42954) (comment: 01600_quota_by_forwarded_ip.sh) (in query: SELECT count() FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.355893 [ 4142 ] {24828a9d-9bc9-437f-bb38-8a1ba068a7e1} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_7` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-03-03 04:04:58. Name of quota template: `quota_by_forwarded_ip_test_7`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2adb7d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:20.364374 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.847640 [ 2824 ] {b5df5b1e-fadc-4ce2-9609-260e7582b1b5} executeQuery: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59222) (comment: 02024_join_on_or_long.gen.sql) (query 3, line 4) (in query: CREATE TABLE t1 (`a` Int64, `b` Int64) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47085, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 88, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 319138825, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 3058396, merge_max_block_size = 1796, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2411543300, index_granularity_bytes = 7684662, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 30, 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 = 61935, primary_key_compress_block_size = 81667, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:20.878057 [ 2824 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:21.354900 [ 5476 ] {f2853cc6-870d-47a0-941d-98f73cd3ad81} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 1) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_az2mbsvi' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%' SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:23:21.424825 [ 5476 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:23:21.542302 [ 4142 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:22.576212 [ 6922 ] {aadf76d8-d9c1-47b3-b27b-b7664fbd3d01} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (3) differs with number of rows with sign = -1 (0) by more than one (for key: 'string2').). 2025.07.13 02:23:22.679742 [ 6922 ] {aadf76d8-d9c1-47b3-b27b-b7664fbd3d01} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 'string2').). 2025.07.13 02:23:24.134476 [ 5072 ] {e0aa1966-a72c-4409-af61-e525e5a4e6d3} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42996) (comment: 01783_parallel_formatting_memory.sh) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d47c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa64bee 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa43ca4 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faada5d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002fab0626 14. ./build_docker/./src/Processors/Transforms/MaterializingTransform.cpp:21: DB::MaterializingTransform::transform(DB::Chunk&) @ 0x0000000031de2301 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 23. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 24. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 25. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:23:24.139343 [ 5072 ] {e0aa1966-a72c-4409-af61-e525e5a4e6d3} DynamicQueryHandler: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d47c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa64bee 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa43ca4 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faada5d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002fab0626 14. ./build_docker/./src/Processors/Transforms/MaterializingTransform.cpp:21: DB::MaterializingTransform::transform(DB::Chunk&) @ 0x0000000031de2301 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 21. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 23. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 24. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 25. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:24.770264 [ 2825 ] {6e2dd84e-df9a-4f49-a31c-df25327ccc86} 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.3.20372.altinityantalya (altinity build)) (from [::1]:59434) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8184c 5. ./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*) @ 0x000000002b07d020 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b0763c8 7. ./src/Core/callOnTypeIndex.h:280: 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&&) @ 0x000000002b00ec8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b019dde 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b018c43 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:23:24.805091 [ 2825 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8184c 5. ./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*) @ 0x000000002b07d020 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b0763c8 7. ./src/Core/callOnTypeIndex.h:280: 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&&) @ 0x000000002b00ec8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b019dde 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b018c43 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:23:27.981433 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:31.619123 [ 3816 ] {8127a376-baa7-4f5d-8de8-64baa8c21b37} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 1, line 1) (in query: -- Error cases SELECT toUnixTimestamp64Second();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:31.651276 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:31.760149 [ 3816 ] {9c94ffb3-9ad0-496f-bc5f-dd585f536b1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 2, line 3) (in query: SELECT toUnixTimestamp64Milli();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:31.776508 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:31.864241 [ 3816 ] {0d3a8123-a96e-4b1d-9030-bf8856d978e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 3, line 4) (in query: SELECT toUnixTimestamp64Micro();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:31.874321 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.003084 [ 3816 ] {d4e284df-fcc8-4149-992a-e8cbc77fc022} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 4, line 5) (in query: SELECT toUnixTimestamp64Nano();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.017106 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.302593 [ 3816 ] {9b7f16c5-33bb-4033-b812-2275d9fe0c7c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Second('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 5, line 7) (in query: SELECT toUnixTimestamp64Second('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.307468 [ 3816 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Second('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.397262 [ 3816 ] {3534feab-c51a-4f9f-8d0c-28b6a10b6b93} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 6, line 8) (in query: SELECT toUnixTimestamp64Milli('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.406182 [ 3816 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.474522 [ 3816 ] {f66e71cf-9045-4f5f-8526-e2e1a5db4fa4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 7, line 9) (in query: SELECT toUnixTimestamp64Micro('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.492143 [ 3816 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.585240 [ 3816 ] {de88c754-90fc-42b9-bba4-870c45514e2b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 8, line 10) (in query: SELECT toUnixTimestamp64Nano('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.590649 [ 3816 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020c0348a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:23:32.655302 [ 3816 ] {63402162-f5d8-4091-90c7-bceb88f14f04} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 9, line 12) (in query: SELECT toUnixTimestamp64Second('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.659872 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.752154 [ 3816 ] {dd622d70-644b-49a1-9738-7f4e06cce506} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 10, line 13) (in query: SELECT toUnixTimestamp64Milli('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.755945 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.821843 [ 3816 ] {01f178f3-43e0-4530-836b-5a933e5afabf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 11, line 14) (in query: SELECT toUnixTimestamp64Micro('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.827777 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.902361 [ 3816 ] {425a3c37-8532-4143-b0f0-8ffb62f54024} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (comment: 01277_toUnixTimestamp64.sql) (query 12, line 15) (in query: SELECT toUnixTimestamp64Nano('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:32.905122 [ 3816 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:23:33.809365 [ 4529 ] {de9402c7-5d6b-428b-87bc-cc8b79b9e147} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42574) (comment: 02441_alter_delete_and_drop_column.sql) (in query: DROP DATABASE IF EXISTS test_5drt0u7e SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:23:33.812032 [ 4529 ] {de9402c7-5d6b-428b-87bc-cc8b79b9e147} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:33.996280 [ 5105 ] {8f194203-5e76-424f-997e-e789efeb665e} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35136) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 4, line 5) (in query: CREATE TABLE t1 (`k` UInt32, `v` String) ENGINE = ReplicatedMergeTree('/02946_parallel_replicas/{database}/test_tbl', 'r1') ORDER BY k SETTINGS index_granularity = 9927, min_bytes_for_wide_part = 542392844, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 113, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 118497673, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 22500814, merge_max_block_size = 1590, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 824179, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1676411884, index_granularity_bytes = 10387132, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 59, 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 = 39173, primary_key_compress_block_size = 19994, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:34.008266 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:39.743851 [ 3816 ] {29fc22d7-65dc-4171-8256-7ea334c668c2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57028) (comment: 02990_optimize_uniq_to_count_alias.sql) (in query: DROP DATABASE IF EXISTS test_b2gfvou8 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:23:39.745996 [ 3816 ] {29fc22d7-65dc-4171-8256-7ea334c668c2} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:44.141901 [ 4142 ] {acd9f2e5-ae12-4d4c-9903-c62bdf3aa5fe} executeQuery: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57770) (comment: 01732_union_and_union_all.sql) (query 1, line 1) (in query: select 1 UNION select 1 UNION ALL select 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002deda3d1 6. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:36: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002ded8a03 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002c75ae82 8. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2aa501 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:44.159820 [ 4142 ] {} TCPHandler: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002deda3d1 6. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:36: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x000000002ded8a03 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002c75ae82 8. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2aa501 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:45.156446 [ 7056 ] {bf242093-571d-4c35-b0e1-3c5275e178b5} executeQuery: Code: 572. DB::Exception: Too many optimizations applied to query plan. Current limit 1. (TOO_MANY_QUERY_PLAN_OPTIMIZATIONS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57796) (comment: 01655_plan_optimizations.sh) (query 1, line 1) (in query: select x + 1 from (select y + 2 as x from (select dummy + 3 as y)) settings query_plan_max_optimizations_to_apply = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:87: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032288ccd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddd4 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:45.191777 [ 7056 ] {} TCPHandler: Code: 572. DB::Exception: Too many optimizations applied to query plan. Current limit 1. (TOO_MANY_QUERY_PLAN_OPTIMIZATIONS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:87: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032288ccd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddd4 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:47.642222 [ 4142 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:47.645674 [ 4142 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:48.292917 [ 3863 ] {10c9c6ef-067e-4ef1-85d4-200312421d69} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage FuzzJSON. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57952) (comment: 02919_storage_fuzzjson.sql) (query 12, line 44) (in query: DROP TABLE IF EXISTS 02919_test_table_reuse_args;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:23:48.297849 [ 3863 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage FuzzJSON. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:23:48.976891 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:48.979421 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:50.349677 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:50.357621 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:51.707609 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:51.708333 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:51.773634 [ 7056 ] {5f79b155-7fca-4760-bef1-14ebd61a68fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=846). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57812) (comment: 01107_join_right_table_totals.sql) (query 25, line 98) (in query: SELECT * FROM (SELECT item_id, 'foo' AS key, 1 AS val FROM t GROUP BY item_id WITH TOTALS ORDER BY item_id) l LEFT JOIN (SELECT item_id, sum(price_sold) AS val FROM t GROUP BY item_id WITH TOTALS ORDER BY item_id ) r ON l.item_id = r.item_id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:51.817829 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=846). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:52.925576 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:52.926637 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:54.256620 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:54.260030 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:54.765006 [ 2824 ] {05315fd5-aa80-4f79-9276-7cae3f377ad3} executeQuery: Code: 456. DB::Exception: Substitution `s` is not set. (UNKNOWN_QUERY_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53644) (comment: 00954_client_prepared_statements.sh) (query 1, line 1) (in query: SELECT {s:String}), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x000000002e28f256 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e28d29d 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a9933 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:23:54.782262 [ 2824 ] {} TCPHandler: Code: 456. DB::Exception: Substitution `s` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x000000002e28f256 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e28d29d 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e28f036 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a9933 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:23:55.441866 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:55.442691 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:56.786904 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:56.787687 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:58.242437 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:23:58.252220 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:23:58.448198 [ 6126 ] {62414c82-165d-4b69-9429-4470c2529537} executeQuery: Code: 57. DB::Exception: Table test_9b7ens1h.tbl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53942) (comment: 02047_log_family_data_file_sizes.sh) (query 1, line 1) (in query: CREATE TABLE tbl(x UInt32, y String) ENGINE=TinyLog), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:23:58.514303 [ 6126 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9b7ens1h.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:00.515517 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:00.516538 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:01.875706 [ 6951 ] {14071242-1d1a-4c1e-a4a0-1650e601c3c0} executeQuery: Code: 57. DB::Exception: Table test_9b7ens1h.tbl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40408) (comment: 02047_log_family_data_file_sizes.sh) (query 1, line 1) (in query: CREATE TABLE tbl(x UInt32, y String) ENGINE=StripeLog), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:01.901607 [ 6951 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9b7ens1h.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:01.942196 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:01.948982 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.496120 [ 5072 ] {9506fb39-4f64-41c4-8fee-b8797c823c18} executeQuery: Code: 44. DB::Exception: Constant columns are not supported at the moment. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40258) (comment: 01602_runningConcurrency.sql) (query 20, line 37) (in query: -- Constant columns are currently not supported. SELECT runningConcurrency(toDate(arrayJoin([1, 2])), toDate('2000-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002076d226 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 15. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 16. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 17. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.513295 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Constant columns are not supported at the moment. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002076d226 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 15. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 16. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 17. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.701300 [ 5072 ] {eb2d3ab4-775d-4d9c-a2b3-c65e339c70cd} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency('strings are', 'not supported'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40258) (comment: 01602_runningConcurrency.sql) (query 21, line 40) (in query: -- Unsupported data types SELECT runningConcurrency('strings are', 'not supported');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000002076b507 6. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b08d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.724555 [ 5072 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency('strings are', 'not supported'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000002076b507 6. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b08d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.804793 [ 5072 ] {09bc8b50-ef1f-4b42-96bb-147a528cf6c8} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40258) (comment: 01602_runningConcurrency.sql) (query 22, line 42) (in query: SELECT runningConcurrency(NULL, NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000002076b507 6. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b08d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.807245 [ 5072 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000002076b507 6. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b08d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.835346 [ 5072 ] {427844d9-6a71-4500-a7be-6ade272b9ef2} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(CAST(NULL, 'Nullable(DateTime)'), CAST(NULL, 'Nullable(DateTime)')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40258) (comment: 01602_runningConcurrency.sql) (query 23, line 43) (in query: SELECT runningConcurrency(CAST(NULL, 'Nullable(DateTime)'), CAST(NULL, 'Nullable(DateTime)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000002076b507 6. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b08d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:02.847827 [ 5072 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(CAST(NULL, 'Nullable(DateTime)'), CAST(NULL, 'Nullable(DateTime)')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000002076b507 6. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b08d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:03.009708 [ 5072 ] {3e88692c-2e52-4385-abc7-506e9aba24a3} executeQuery: Code: 43. DB::Exception: Function runningConcurrency must be called with two arguments having the same type.: In scope SELECT runningConcurrency(toDate('2000-01-01'), toDateTime('2000-01-01 00:00:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40258) (comment: 01602_runningConcurrency.sql) (query 24, line 45) (in query: -- Mismatching data types SELECT runningConcurrency(toDate('2000-01-01'), toDateTime('2000-01-01 00:00:00'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b198 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:24:03.021102 [ 5072 ] {} TCPHandler: Code: 43. DB::Exception: Function runningConcurrency must be called with two arguments having the same type.: In scope SELECT runningConcurrency(toDate('2000-01-01'), toDateTime('2000-01-01 00:00:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002076b198 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfe06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:24:03.056831 [ 2824 ] {e9d0dd59-c4a1-439a-bbf8-8457efbd3b76} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40452) (comment: 02281_limit_by_distributed.sql) (query 1, line 1) (in query: SELECT k FROM ( SELECT k, abs(v) AS _v FROM remote('127.{1,2}', view(select materialize('foo') as k, -1 as v)) ORDER BY _v ASC LIMIT 1 BY k ) GROUP BY k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:03.080346 [ 2824 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:03.251788 [ 5072 ] {89559afc-4636-43bb-af84-3d72931ab96d} executeQuery: Code: 117. DB::Exception: Incorrect order of events: '2000-01-02' > '2000-01-01': In scope SELECT runningConcurrency(toDate('2000-01-02'), toDate('2000-01-01')). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40258) (comment: 01602_runningConcurrency.sql) (query 25, line 48) (in query: -- begin > end SELECT runningConcurrency(toDate('2000-01-02'), toDate('2000-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002076d0e2 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:24:03.254247 [ 5072 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect order of events: '2000-01-02' > '2000-01-01': In scope SELECT runningConcurrency(toDate('2000-01-02'), toDate('2000-01-01')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002076d0e2 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:24:04.256170 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:04.260464 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:07.826970 [ 3465 ] {fc708796-2ceb-4fd9-9caf-9af502085f49::all_1_1_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:07.835787 [ 3465 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fc708796-2ceb-4fd9-9caf-9af502085f49::all_1_1_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:08.109258 [ 4529 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:09.882467 [ 5379 ] {ab580025-d7b1-443f-8d85-c5656e26ed07} executeQuery: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40710) (comment: 01451_detach_drop_part.sql) (query 8, line 12) (in query: ALTER TABLE mt_01451 DETACH PART 'all_100_100_0';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5458: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x0000000030d080e1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5685: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f45e 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:24:09.886396 [ 5379 ] {} TCPHandler: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5458: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x0000000030d080e1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5685: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f45e 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.180612 [ 5379 ] {acf8eeff-dd0a-4541-982a-e60aa2d918e2} executeQuery: Code: 233. DB::Exception: Detached part "all_4_4_0" not found. (BAD_DATA_PART_NAME) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40710) (comment: 01451_detach_drop_part.sql) (query 17, line 30) (in query: ALTER TABLE mt_01451 ATTACH PART 'all_4_4_0';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7965: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x0000000030d20bb2 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6764: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x0000000030d2211b 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:2184: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000031208d84 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5705: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e178 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.198364 [ 5379 ] {} TCPHandler: Code: 233. DB::Exception: Detached part "all_4_4_0" not found. (BAD_DATA_PART_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7965: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x0000000030d20bb2 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6764: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x0000000030d2211b 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:2184: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000031208d84 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5705: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e178 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.231677 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.232759 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.520950 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.529731 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.846583 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:12.848139 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:13.227823 [ 2825 ] {8c75eed6-a03e-430e-9a14-dd7ece6de40e} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 22.16 MiB (attempt to allocate chunk of 4.00 MiB), maximum: 9.31 GiB: While executing StripeLog. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34962) (comment: 01651_lc_insert_tiny_log_3.sql) (query 8, line 13) (in query: select sum(length(arr)) from perf_lc_num;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017d47b34 10. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000187627d1 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c602b47 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:596: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c5d4d66 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c54a24b 14. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x00000000317babfc 15. ./build_docker/./src/Storages/StorageStripeLog.cpp:131: DB::StripeLogSource::generate() @ 0x000000003088844b 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:13.332846 [ 2825 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 22.16 MiB (attempt to allocate chunk of 4.00 MiB), maximum: 9.31 GiB: While executing StripeLog. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017d47b34 10. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000187627d1 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c602b47 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:596: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c5d4d66 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c54a24b 14. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x00000000317babfc 15. ./build_docker/./src/Storages/StorageStripeLog.cpp:131: DB::StripeLogSource::generate() @ 0x000000003088844b 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:13.485172 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:13.489907 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:13.892360 [ 4529 ] {f1651dfa-97c1-4164-af98-3803489e2969} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `_partition_value` in scope SELECT _partition_value FROM tbl2. Maybe you meant: ['_partition_id']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50560) (comment: 01848_partition_value_column.sql) (query 12, line 17) (in query: select _partition_value from tbl2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:13.905022 [ 4529 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `_partition_value` in scope SELECT _partition_value FROM tbl2. Maybe you meant: ['_partition_id']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:14.027874 [ 4529 ] {0839f23e-869b-4598-ad8f-862a496ff80f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `_partition_value` in scope SELECT _partition_value FROM tbl2 GROUP BY 1. Maybe you meant: ['_partition_id']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50560) (comment: 01848_partition_value_column.sql) (query 13, line 18) (in query: select _partition_value from tbl2 group by 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:14.064467 [ 4529 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `_partition_value` in scope SELECT _partition_value FROM tbl2 GROUP BY 1. Maybe you meant: ['_partition_id']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:14.376710 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:14.380034 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:17.570898 [ 3462 ] {2e3b34c4-cd42-4f3e-ac4c-01dc87d6bc60::all_1_61_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:17.572431 [ 3462 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2e3b34c4-cd42-4f3e-ac4c-01dc87d6bc60::all_1_61_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:19.786214 [ 4529 ] {c182b519-a301-4519-9f73-8236c3ee221f} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42314) (comment: 02429_offset_pipeline_stuck_bug.sql) (query 1, line 1) (in query: CREATE TABLE t ENGINE = Log AS SELECT * FROM system.numbers LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:19.822959 [ 4529 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.027984 [ 29256 ] {7a54aa7a-c2e8-4c20-87f2-de8a41337c7c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42308) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 1) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_az2mbsvi' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%' SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.034631 [ 29256 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.439218 [ 29256 ] {c76e38b1-c3b7-4e0c-a5a4-aaa3cad5a701} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42340) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.448038 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.909548 [ 5971 ] {52c13d24-b2bc-4961-abb3-d72c7531cd58} Context: Server has databases (for example `ordinary_test_9qz8o2qg`) 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.13 02:24:20.944156 [ 5379 ] {70234336-1e39-43ba-ad9c-02639b12fc84} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53986) (comment: 00871_t64_codec_signed.sql) (in query: DROP DATABASE IF EXISTS test_atb3thho SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.947233 [ 5379 ] {70234336-1e39-43ba-ad9c-02639b12fc84} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:20.956732 [ 29256 ] {5d085478-94a7-4a0a-a2ff-fbcf0b7574e2} executeQuery: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42392) (comment: 02456_alter-nullable-column-bag-2.sql) (query 2, line 2) (in query: CREATE TABLE t1 (`v` UInt64) ENGINE = ReplicatedMergeTree('/test/tables/{database}/test/t1', 'r1') PARTITION BY v ORDER BY v SETTINGS index_granularity = 34743, min_bytes_for_wide_part = 1047239732, 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 = 416515579, compact_parts_max_bytes_to_buffer = 508529509, compact_parts_max_granules_to_buffer = 112, compact_parts_merge_max_bytes_to_prefetch_part = 1344724, merge_max_block_size = 7710, old_parts_lifetime = 249., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 2653561, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 96, 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 = 50039, primary_key_compress_block_size = 85662, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:20.976772 [ 29256 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:21.047036 [ 4529 ] {7ea86fe7-23bf-4f8a-8d24-8b2dd42d5ae6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53988) (comment: 00871_t64_codec_signed.sql) (in query: DROP DATABASE IF EXISTS test_atb3thho SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:21.049041 [ 4529 ] {7ea86fe7-23bf-4f8a-8d24-8b2dd42d5ae6} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:21.643809 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:21.842784 [ 4529 ] {dc031f3b-b781-459c-bf91-d19e36d849a4} executeQuery: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42948) (comment: 02009_from_infile.sh) (in query: INSERT INTO test_infile_url FROM INFILE '/repo/tests/queries/0_stateless/test_infile.gz' FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000031f16b60 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcef996 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:24:21.846663 [ 4529 ] {dc031f3b-b781-459c-bf91-d19e36d849a4} DynamicQueryHandler: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000031f16b60 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcef996 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:22.120285 [ 4529 ] {c3d1b6eb-c0d3-437f-8524-944e7396f0c3} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress, the number of elements in the compressed data (65) is not equal to the expected number of elements in the decompressed data (1). (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Compression/CompressionCodecT64.cpp:589: DB::CompressionCodecT64::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000032dd7349 6. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000032e03ccd 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: DB::CompressedReadBuffer::nextImpl() @ 0x0000000032da71ba 8. DB::ReadBuffer::next() @ 0x0000000017e75832 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000023b2a091 10. DB::ReadBuffer::next() @ 0x0000000017e75832 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x000000002d415020 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b37a0 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:23.337650 [ 6126 ] {306ebd55-6fc9-4d8c-96ef-73d4c370806e} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE data; to attach existing table or CREATE TABLE data
; to create new table or ATTACH TABLE data FROM '/path/to/data/'
; to create new table and attach data. 2025.07.13 02:24:23.661896 [ 7056 ] {1ab8a2d6-f0ae-422e-b7ab-65713e232040} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 12, line 18) (in query: SELECT tupleElement(number, 1) FROM numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0550b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:23.697369 [ 7056 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0550b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:23.827944 [ 7056 ] {3ba04e3a-f447-4e07-aafc-efae18e9a1ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 13, line 19) (in query: SELECT tupleElement(t1) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:23.847455 [ 7056 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:23.927370 [ 7056 ] {56ac3b9a-c905-4729-ba12-e29738fd8d39} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 14, line 20) (in query: SELECT tupleElement(t1, 'b') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:23.944566 [ 7056 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.119310 [ 7056 ] {039ce3f7-3dd4-4624-b555-2b841707b6fb} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 15, line 21) (in query: SELECT tupleElement(t1, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.126316 [ 7056 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.231541 [ 7056 ] {11e26c0c-3d10-4cd4-842e-e7fea830cda1} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 16, line 22) (in query: SELECT tupleElement(t1, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.235825 [ 7056 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.387122 [ 7056 ] {cd5e58af-8333-48e5-abf4-dca30398d5ed} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 17, line 23) (in query: SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.400530 [ 7056 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.836631 [ 6126 ] {f4ce5df9-acf2-47cd-ac31-fec487e6fe6d} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42516) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (query 4, line 12) (in query: insert into data values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311d680e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:341: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000311d65e2 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.845036 [ 6126 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311d680e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:341: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000311d65e2 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: 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&) @ 0x0000000031eff7ef 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.932808 [ 6126 ] {4cf77b8d-6ab4-457c-8b66-b37a6c4129c9} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42516) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (query 5, line 13) (in query: optimize table data final;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311d680e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1645: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311f3895 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:24.937098 [ 6126 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311d680e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1645: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311f3895 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.002220 [ 7056 ] {980dc2a0-f661-440b-b915-a4b1ccdb4e5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 22, line 31) (in query: SELECT tupleElement(t2) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.011466 [ 7056 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.090333 [ 7056 ] {7a50a707-18f0-4695-a731-712a3da9c127} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 23, line 32) (in query: SELECT tupleElement(t2, 'a') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.103353 [ 7056 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.176133 [ 7056 ] {2ca87ac8-4bad-4b6f-8ba3-469b895e36fa} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 24, line 33) (in query: SELECT tupleElement(t2, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.181235 [ 7056 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.265536 [ 7056 ] {dcd69b50-e412-4816-ba50-5deee2422b6f} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 25, line 34) (in query: SELECT tupleElement(t2, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.295727 [ 7056 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.419646 [ 7056 ] {11a9262a-b81d-4ecc-8a51-1ce0edb1e5fa} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42454) (comment: 02116_tuple_element_analyzer.sql) (query 26, line 35) (in query: SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.431632 [ 7056 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.433928 [ 2824 ] {12421c62-0201-41d7-b771-f15fc2ad3c65} executeQuery: Code: 57. DB::Exception: Table test_pexr9zrg.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50796) (comment: 02342_analyzer_compound_types.sql) (query 58, line 149) (in query: CREATE TABLE test_table (`id` UInt64, `value` Nested(value_0_level_0 Nested(value_0_level_1 String, value_1_level_1 String), value_1_level_0 String)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 17924, 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 = 146591062, compact_parts_max_bytes_to_buffer = 370983428, compact_parts_max_granules_to_buffer = 102, compact_parts_merge_max_bytes_to_prefetch_part = 3997291, merge_max_block_size = 24068, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 797792, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7193905438, index_granularity_bytes = 2377885, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 42, 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 = 96744, primary_key_compress_block_size = 41539, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.456733 [ 2824 ] {} TCPHandler: Code: 57. DB::Exception: Table test_pexr9zrg.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.629881 [ 4529 ] {cf60f453-ce59-4139-8ad9-bf34bce85e01} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54040) (comment: 02342_analyzer_compound_types.sql) (in query: DROP DATABASE IF EXISTS test_pexr9zrg SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:25.631499 [ 4529 ] {cf60f453-ce59-4139-8ad9-bf34bce85e01} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:26.311575 [ 6951 ] {14184057-b66c-42f6-a680-437c8d18803d} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42292) (comment: 02842_mutations_replace_non_deterministic.sql) (query 15, line 37) (in query: -- Too big result. ALTER TABLE t_mutations_nondeterministic UPDATE v = (SELECT groupArray(number) FROM numbers(10000)) WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1407: DB::MutationsInterpreter::validate() @ 0x000000002debe063 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd01 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:26.321217 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1407: DB::MutationsInterpreter::validate() @ 0x000000002debe063 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd01 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:26.680579 [ 29256 ] {3c27bd3a-5f67-4b14-82d3-0a05d9ffc692} 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.3.20372.altinityantalya (altinity build)) (from [::1]:42522) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 12, line 21) (in query: CREATE TABLE table_1017_1 (`x` UInt32, `y` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_5/table_1017', 'r1') ORDER BY x SETTINGS index_granularity = 36180, min_bytes_for_wide_part = 147648329, 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 = 120777291, compact_parts_max_granules_to_buffer = 94, compact_parts_merge_max_bytes_to_prefetch_part = 3109931, merge_max_block_size = 11474, 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 = 10737418240, index_granularity_bytes = 20936985, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 66, 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 = 14793, primary_key_compress_block_size = 22645, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:26.696252 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:27.036043 [ 5379 ] {bb1dc197-f4de-464f-97aa-aa4b03a611c2} executeQuery: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (query 5, line 10) (in query: CREATE TABLE ignore_auto_increment ( id int AUTO_INCREMENT ) ENGINE=MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:662: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc687fd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:24:27.054699 [ 5379 ] {} TCPHandler: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:662: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc687fd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:24:27.069263 [ 3816 ] {8aaf1403-e7c1-4d93-98c5-5f3be6de6f80} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42646) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 DELETE WHERE ignore(rand())), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:27.094155 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:27.544283 [ 3816 ] {bbf042b1-3fb3-4bc2-8f7c-9958664fccf8} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42670) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = y + rand() % 1 WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:27.574679 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.075615 [ 2824 ] {42900172-347e-4b1b-99f4-47707899085a} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42696) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = x + arrayCount(x -> (x + y) % 2, range(y)) WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.096604 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.432032 [ 2825 ] {b29df386-e054-40dd-b446-4d6e51b6c252} executeQuery: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42620) (comment: 03363_join_multiple_swap.gen.sql) (query 5, line 7) (in query: CREATE TABLE t1 (`k` String, `a` Int32) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 3393, min_bytes_for_wide_part = 852888260, 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 = 0, compact_parts_max_bytes_to_buffer = 496897136, compact_parts_max_granules_to_buffer = 38, compact_parts_merge_max_bytes_to_prefetch_part = 361052, merge_max_block_size = 21764, old_parts_lifetime = 327., prefer_fetch_merged_part_size_threshold = 4126323349, 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 = 26518621, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 42, 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 = 84768, primary_key_compress_block_size = 52523, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.458755 [ 2825 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.547599 [ 3816 ] {e21c8547-0eef-4d5a-a93e-65b7eb0e579b} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42704) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = x + arrayCount(x -> (rand() + x) % 2, range(y)) WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.577076 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.906169 [ 2825 ] {ccc43067-41ac-42b3-839f-aab78deff648} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_merge does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54368) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_merge DELETE WHERE rand() = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:28.910109 [ 2825 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_merge does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:29.144142 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:29.444862 [ 2824 ] {8a0a90ff-e9b9-42e0-b4e7-f5931cafa468} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_merge does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54388) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_merge UPDATE y = y + rand() % 1 WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:29.476233 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_merge does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:29.853440 [ 6884 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:29.933344 [ 2825 ] {159626de-4ad3-4ab3-b4bc-62c93391a611} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54418) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = joinGet('test_5.lookup_table', 'y_new', y) WHERE x=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:29.956746 [ 2825 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.367862 [ 2824 ] {bd8171a6-01df-4712-9661-c2ff4c65f353} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE rdb_test_11.mt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.409673 [ 4529 ] {22c6800d-33a1-4e80-b8f2-673dbff9fe18} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54458) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 DELETE WHERE dictHas('test_5.dict1', toUInt64(x))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.436655 [ 4529 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.439229 [ 2824 ] {bd8171a6-01df-4712-9661-c2ff4c65f353} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54430) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.448691 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.896042 [ 2824 ] {f8db5b7e-f2c4-4480-8cd9-f4486d63a568} executeQuery: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54476) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 DELETE WHERE dictHas('test_5.dict1', toUInt64(x))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:30.920093 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.table_1017_1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:31.511994 [ 5072 ] {4301960e-737a-4151-8bc6-1408f495cd89} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE rdb_test_11.rmt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:31.533744 [ 6951 ] {b74c5652-c63f-48ec-8891-db6841868b89} executeQuery: Code: 57. DB::Exception: Table test_3.t_mutations_nondeterministic already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42292) (comment: 02842_mutations_replace_non_deterministic.sql) (query 24, line 64) (in query: CREATE TABLE t_mutations_nondeterministic (`id` UInt64, `v` DateTime) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/02842_mutations_replace', '1') ORDER BY id SETTINGS index_granularity = 39034, min_bytes_for_wide_part = 795262682, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 15, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 496891928, compact_parts_max_granules_to_buffer = 42, compact_parts_merge_max_bytes_to_prefetch_part = 2623083, merge_max_block_size = 14941, 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 = 4787980308, index_granularity_bytes = 2514150, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 4, 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 = 25119, primary_key_compress_block_size = 82909, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:31.540822 [ 6951 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t_mutations_nondeterministic already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:31.575442 [ 5072 ] {4301960e-737a-4151-8bc6-1408f495cd89} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54480) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:31.632338 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.026360 [ 7056 ] {f032706f-767f-448c-963c-d4459d2ac828} executeQuery: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54568) (comment: 01548_uncomparable_columns_in_keys.sql) (query 2, line 3) (in query: CREATE TABLE foo (`id` UInt64, `key` AggregateFunction(max, UInt64)) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 50387, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 61, min_bytes_for_full_part_storage = 469448085, compact_parts_max_bytes_to_buffer = 122152665, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 22971417, merge_max_block_size = 12044, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8212219, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 66, 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 = 10516, primary_key_compress_block_size = 99318, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.051062 [ 7056 ] {} TCPHandler: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.206480 [ 7056 ] {4bd200f9-70b7-4c37-8400-dbb9ece95147} executeQuery: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54568) (comment: 01548_uncomparable_columns_in_keys.sql) (query 3, line 5) (in query: CREATE TABLE foo (`id` UInt64, `key` AggregateFunction(max, UInt64)) ENGINE = MergeTree PARTITION BY key SETTINGS index_granularity = 50387, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 61, min_bytes_for_full_part_storage = 469448085, compact_parts_max_bytes_to_buffer = 122152665, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 22971417, merge_max_block_size = 12044, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8212219, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 66, 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 = 10516, primary_key_compress_block_size = 99318, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003033c015 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c4f55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.220073 [ 7056 ] {} TCPHandler: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003033c015 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c4f55 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.380022 [ 7056 ] {52be7181-c752-4131-9008-b764982a9a65} executeQuery: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54568) (comment: 01548_uncomparable_columns_in_keys.sql) (query 4, line 7) (in query: CREATE TABLE foo (`id` UInt64, `key` AggregateFunction(max, UInt64)) ENGINE = MergeTree ORDER BY key SAMPLE BY key SETTINGS index_granularity = 50387, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 61, min_bytes_for_full_part_storage = 469448085, compact_parts_max_bytes_to_buffer = 122152665, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 22971417, merge_max_block_size = 12044, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8212219, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 66, 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 = 10516, primary_key_compress_block_size = 99318, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.405223 [ 7056 ] {} TCPHandler: Code: 549. DB::Exception: Column `key` with type AggregateFunction(max, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033b771 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c632b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.422152 [ 2825 ] {4bac27ac-ad01-42b1-81eb-5f73ccb6bb9a} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000008 */ ALTER TABLE rdb_test_11.mt (DROP PARTITION ID 'all'), (UPDATE n = 2 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.449164 [ 2825 ] {4bac27ac-ad01-42b1-81eb-5f73ccb6bb9a} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54600) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:32.468851 [ 2825 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:33.434992 [ 6126 ] {93f57caa-4c59-4776-bad1-5660d2034cbc} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000009 */ ALTER TABLE rdb_test_11.rmt (DROP PARTITION ID 'all'), (UPDATE n = 2 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:33.484169 [ 6126 ] {93f57caa-4c59-4776-bad1-5660d2034cbc} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54630) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:33.491832 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:34.508498 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:34.978366 [ 6884 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:37.925537 [ 3816 ] {b2e9ab58-01a3-404e-ac86-f7926a823491} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000010 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.139992104 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54692) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:37.952108 [ 3816 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000010 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.139992104 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:38.091676 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:38.105034 [ 4529 ] {6ae4e735-b558-43f4-b5fb-28d33f6ee57f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54842) (comment: 01291_aggregation_in_order.sql) (query 10, line 16) (in query: SELECT a, sum(c), avg(d) FROM pk_order GROUP BY a ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:24:38.228806 [ 4529 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:39.899764 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:40.205245 [ 6884 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:41.476353 [ 5072 ] {9617f92b-7351-4aaa-b873-35bb73310d3f} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.04 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x00000000239925e1 9. ./src/Common/HashTable/HashTable.h:491: TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>* std::construct_at[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*>(TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*) @ 0x000000002e4fdc8f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>>::__shared_ptr_emplace[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>) @ 0x000000002e4fdb1b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x000000002e4fd999 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x000000002e4f7d9b 13. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x000000002e455ae6 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x000000002e45268a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002dbab911 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 4. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 8. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:41.514402 [ 5072 ] {9617f92b-7351-4aaa-b873-35bb73310d3f} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.04 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54938) (comment: 00820_multiple_joins.sql) (query 19, line 37) (in query: select t1.a as t1_a, t2.a as t2_a, t2.b as t2_b, t3.b as t3_b from table1 as t1 join table2 as t2 on t1.a = t2.a join table3 as t3 on t2.b = t3.b ORDER BY t1.a ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x00000000239925e1 9. ./src/Common/HashTable/HashTable.h:491: TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>* std::construct_at[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*>(TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*) @ 0x000000002e4fdc8f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>>::__shared_ptr_emplace[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>) @ 0x000000002e4fdb1b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x000000002e4fd999 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x000000002e4f7d9b 13. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x000000002e455ae6 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x000000002e45268a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002dbab911 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:41.537540 [ 5072 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.04 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x00000000239925e1 9. ./src/Common/HashTable/HashTable.h:491: TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>* std::construct_at[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*>(TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>*) @ 0x000000002e4fdc8f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>>::__shared_ptr_emplace[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>) @ 0x000000002e4fdb1b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x000000002e4fd999 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x000000002e4f7d9b 13. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x000000002e455ae6 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x000000002e45268a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002dbab911 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 4. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 8. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:43.373325 [ 10341 ] {08b79f7c-b604-4787-83e8-d2b0546cd917} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000011 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.127992134 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55014) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.rmt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:43.390588 [ 10341 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000011 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.127992134 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:44.326474 [ 33006 ] {f1826de7-0529-4b37-bbe7-83f4483298cb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53134) (comment: 01325_freeze_mutation_stuck.sql) (in query: DROP DATABASE IF EXISTS test_30p7lwgl SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:44.330209 [ 33006 ] {f1826de7-0529-4b37-bbe7-83f4483298cb} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:44.962695 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:45.325801 [ 6884 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:46.765057 [ 5379 ] {91c8e44f-0fc9-403e-b22a-a9eb41fc01be} executeQuery: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48114) (comment: 03267_join_swap_bug.sql) (query 2, line 2) (in query: CREATE TABLE t0 (`c0` Int) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44732, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 37338683, compact_parts_max_bytes_to_buffer = 234101114, compact_parts_max_granules_to_buffer = 183, compact_parts_merge_max_bytes_to_prefetch_part = 11075067, merge_max_block_size = 4832, old_parts_lifetime = 412., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 67, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 17512944, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 77783, primary_key_compress_block_size = 66129, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:46.784189 [ 5379 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:47.672752 [ 10341 ] {e7d06455-783e-4dba-aa25-cdd5d6bbb685} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000012 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.559991049 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47962) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:47.723092 [ 10341 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000012 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.559991049 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:48.152686 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:48.590163 [ 5072 ] {bd3f7b6e-d007-44bd-9ad4-2c9a86ac17d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48204) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 1) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_az2mbsvi' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%' SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:48.638777 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:49.667530 [ 3816 ] {690267ec-06cb-4c4b-b2bb-05641515d2d8} executeQuery: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_index` to drop. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44008) (comment: 00953_indices_alter_exceptions.sh) (query 1, line 1) (in query: ALTER TABLE test_drop_indices DROP INDEX test_index;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/Storages/AlterCommands.cpp:755: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302cd7f6 6. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:49.707479 [ 3816 ] {} TCPHandler: Code: 36. DB::Exception: Wrong index name. Cannot find index `test_index` to drop. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/Storages/AlterCommands.cpp:755: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302cd7f6 6. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:50.018538 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:50.373120 [ 29256 ] {aa85fbc1-be2a-4dd1-bc69-6612e7d5913f} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64('3000-01-01 12:00:00.12345', 0) + toIntervalNanosecond(0). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48098) (comment: 00514_interval_operators.sql) (query 18, line 23) (in query: select toDateTime64('3000-01-01 12:00:00.12345', 0) + interval 0 nanosecond;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000017e3e0f6 6. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e76197 7. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e7360b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddNanosecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018e62909 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018e601a7 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 17. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001fd0cba6 18. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b056 19. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 21. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 2025.07.13 02:24:50.384453 [ 29256 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64('3000-01-01 12:00:00.12345', 0) + toIntervalNanosecond(0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000017e3e0f6 6. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e76197 7. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e7360b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddNanosecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018e62909 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018e601a7 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 17. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001fd0cba6 18. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b056 19. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 20. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 21. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 2025.07.13 02:24:50.437054 [ 6884 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:50.668002 [ 29256 ] {a85ff735-51ca-4683-acb8-46e270a8bce8} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT materialize(toDate('2000-01-01')) + toIntervalNanosecond(1) FROM numbers(0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48098) (comment: 00514_interval_operators.sql) (query 20, line 26) (in query: -- Check that the error is thrown during typechecking, not execution. select materialize(toDate('2000-01-01')) + interval 1 nanosecond from numbers(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x0000000018e7efa2 5. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 7. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001fec9dc9 8. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fb92591 9. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:24:50.678591 [ 29256 ] {} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT materialize(toDate('2000-01-01')) + toIntervalNanosecond(1) FROM numbers(0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x0000000018e7efa2 5. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 7. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001fec9dc9 8. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fb92591 9. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:24:51.040754 [ 2825 ] {f051e410-3073-47c4-80ae-1eec10ac502e} executeQuery: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44134) (comment: 01548_with_totals_having.sql) (query 1, line 1) (in query: SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:77: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca16c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:51.060405 [ 2825 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09fc8f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cca1aed 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:77: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cca16c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc066df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:51.176833 [ 2825 ] {911fad19-0e52-450a-a5de-263280568833} executeQuery: Code: 44. DB::Exception: Having clause cannot contain arrayJoin. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44134) (comment: 01548_with_totals_having.sql) (query 2, line 2) (in query: SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([3, 2, 1, 0]) ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:189: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x0000000031eba71d 6. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:51.192309 [ 2825 ] {} TCPHandler: Code: 44. DB::Exception: Having clause cannot contain arrayJoin. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:189: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x0000000031eba71d 6. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:51.903496 [ 5971 ] {4eb77cf6-e889-474b-84ae-abe51a5a3bf8} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000013 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.4199914 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48188) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:51.921646 [ 5971 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000013 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.4199914 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.165561 [ 5072 ] {efad9526-39ee-40aa-9e22-a8bdb7904371} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 3, line 3) (in query: SELECT toDecimal32OrZero(1.1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./src/Functions/FunctionsConversion.h:2616: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b56c1 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.176994 [ 5072 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./src/Functions/FunctionsConversion.h:2616: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b56c1 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.285788 [ 10341 ] {246330c9-74cf-4639-91fe-1542a90a0f7d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33336) (comment: 02998_analyzer_prewhere_report.sql) (in query: DROP DATABASE IF EXISTS test_grad0ify SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.287347 [ 10341 ] {246330c9-74cf-4639-91fe-1542a90a0f7d} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:52.790697 [ 3885 ] {0353af52-f3b0-4f94-980e-7de7907d55fe} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60002.895511 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53472) (comment: 00988_parallel_parts_removal.sql) (query 5, line 10) (in query: INSERT INTO mt SELECT * FROM numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.804948 [ 6126 ] {dedd08d5-1c74-4d86-aeb2-7b7e682c79ca} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44152) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: -- constant ignore will be pruned by part pruner. ignore(*) is used. SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.839053 [ 3885 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60002.895511 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.844555 [ 6126 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.964033 [ 6126 ] {96e75f39-3fd0-423b-bc0b-126ae790d3af} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44152) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:52.974843 [ 6126 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:24:53.690185 [ 7056 ] {20b7e773-ed2b-4cdd-b997-8343e0eea2a5} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44296) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. _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_ @ 0x0000000019b0ab10 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019af7885 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af6233 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af46a8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:24:53.755738 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. _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_ @ 0x0000000019b0ab10 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019af7885 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af6233 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af46a8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:24:54.180974 [ 7056 ] {a7f7ebf5-1aa2-402e-ad6f-32e6f699b57a} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44296) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x0000000019ae53e9 6. _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_ @ 0x0000000019ba4ca3 7. 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 @ 0x0000000019b0308b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019af7f09 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af6233 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af46a8 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:54.196052 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x0000000019ae53e9 6. _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_ @ 0x0000000019ba4ca3 7. 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 @ 0x0000000019b0308b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019af7f09 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af6233 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af46a8 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:54.365419 [ 5072 ] {3ce099b9-5b95-445c-abd3-edec9b720023} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal32OrZero must be constant: In scope SELECT toDecimal32OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 15, line 18) (in query: SELECT toDecimal32OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b5a2d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:54.378345 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal32OrZero must be constant: In scope SELECT toDecimal32OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b5a2d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:54.498832 [ 5072 ] {a89b0d1b-ff32-4659-95e1-1d1c198d46da} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal64OrZero must be constant: In scope SELECT toDecimal64OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 16, line 19) (in query: SELECT toDecimal64OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal64OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b728d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:54.516239 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal64OrZero must be constant: In scope SELECT toDecimal64OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal64OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b728d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:54.632036 [ 7056 ] {45de0edc-e81d-4231-89bb-658b7db284fc} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44296) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x0000000019addf1a 6. _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_ @ 0x0000000019b9cce4 7. 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 @ 0x0000000019b0302b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019af7ebc 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af6233 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af46a8 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:54.644181 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x0000000019addf1a 6. _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_ @ 0x0000000019b9cce4 7. 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 @ 0x0000000019b0302b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019af7ebc 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af6233 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019af46a8 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:54.949383 [ 5072 ] {f325bbac-5032-4076-baaa-21d1ed60b0e4} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal128OrZero must be constant: In scope SELECT toDecimal128OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 17, line 20) (in query: SELECT toDecimal128OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>>, DB::detail::NameToDecimal128OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b864d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:54.979333 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal128OrZero must be constant: In scope SELECT toDecimal128OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>>, DB::detail::NameToDecimal128OrZero, (DB::detail::ConvertFromStringExceptionMode)1, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2b864d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:55.159740 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:55.208664 [ 7056 ] {e6ce5e0f-d509-430d-856a-b2f0668a714f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44296) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. _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_ @ 0x00000000199aaff0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019997d45 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000199966f3 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019994b68 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:24:55.212094 [ 5115 ] {} test_2ysx3zcq.mt (1eff8405-1d46-49cf-9e80-8a9f68dd2f52): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:24:55.236012 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. _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_ @ 0x00000000199aaff0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019997d45 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000199966f3 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019994b68 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:24:55.610871 [ 5072 ] {05465cca-4b82-466a-9953-e3d624f75805} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 21, line 26) (in query: SELECT toDecimal32OrNull(1.1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./src/Functions/FunctionsConversion.h:2616: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2fd081 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:55.638388 [ 5072 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./src/Functions/FunctionsConversion.h:2616: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2fd081 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:55.792704 [ 7056 ] {79cbea4d-33bc-4fa3-bfed-e2a18eb474e4} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44296) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x0000000019985095 6. _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_ @ 0x0000000019a44fa3 7. 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 @ 0x00000000199a354b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000199983c9 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000199966f3 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019994b68 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:55.809527 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x0000000019985095 6. _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_ @ 0x0000000019a44fa3 7. 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 @ 0x00000000199a354b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000199983c9 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000199966f3 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019994b68 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:55.845299 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:55.846016 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:24:55.855816 [ 33000 ] {87ec87c4-5406-4b6d-842e-d51436b000fe} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:52400) (comment: 01455_opentelemetry_distributed.sh) (in query: select 1 from remote('127.0.0.2', system, one) settings enable_analyzer = 1 format Null ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:24:55.863747 [ 33000 ] {87ec87c4-5406-4b6d-842e-d51436b000fe} DynamicQueryHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:55.920485 [ 5115 ] {} DatabaseCatalog: Cannot drop table test_2ysx3zcq.mt (1eff8405-1d46-49cf-9e80-8a9f68dd2f52). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:56.223752 [ 5105 ] {6471046a-ed5f-4104-b541-e08494971286} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000015 */ ALTER TABLE rdb_test_11.mt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:56.303002 [ 5105 ] {6471046a-ed5f-4104-b541-e08494971286} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44382) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:56.313405 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:56.379613 [ 7056 ] {b328bc26-c24e-44e4-85c3-ab57d25d2492} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44296) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x000000001997d192 6. _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_ @ 0x0000000019a3cfe4 7. 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 @ 0x00000000199a34eb 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001999837c 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000199966f3 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019994b68 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:56.382242 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. 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) @ 0x000000001997d192 6. _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_ @ 0x0000000019a3cfe4 7. 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 @ 0x00000000199a34eb 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001999837c 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000199966f3 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019994b68 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:24:57.321611 [ 5379 ] {de7f584f-0d6d-4342-8149-30ed4d1b44fe} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000016 */ ALTER TABLE rdb_test_11.rmt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.400082 [ 5379 ] {de7f584f-0d6d-4342-8149-30ed4d1b44fe} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44458) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.408200 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5d68a4 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf669 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.469359 [ 29256 ] {e93410d4-c77b-4720-b2a6-481bfc0e52e5} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress, the number of elements in the compressed data (65) is not equal to the expected number of elements in the decompressed data (1). (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Compression/CompressionCodecT64.cpp:589: DB::CompressionCodecT64::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000032dd7349 6. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000032e03ccd 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: DB::CompressedReadBuffer::nextImpl() @ 0x0000000032da71ba 8. DB::ReadBuffer::next() @ 0x0000000017e75832 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000023b2a091 10. DB::ReadBuffer::next() @ 0x0000000017e75832 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x000000002d415020 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b37a0 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:57.531653 [ 5072 ] {6aa087fd-38e4-4108-8791-78b35764eed6} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal32OrNull must be constant: In scope SELECT toDecimal32OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 33, line 41) (in query: SELECT toDecimal32OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2fd40d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.539966 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal32OrNull must be constant: In scope SELECT toDecimal32OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal32OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2fd40d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.738660 [ 5072 ] {e5057880-2d6f-4e99-94af-4ae55b3fd549} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal64OrNull must be constant: In scope SELECT toDecimal64OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 34, line 42) (in query: SELECT toDecimal64OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal64OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2fe88d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.752034 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal64OrNull must be constant: In scope SELECT toDecimal64OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>, DB::detail::NameToDecimal64OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2fe88d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.853738 [ 5072 ] {e35ada56-4cc2-48c6-9cfd-1a4c72619164} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal128OrNull must be constant: In scope SELECT toDecimal128OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44184) (comment: 00700_to_decimal_or_something.sql) (query 35, line 43) (in query: SELECT toDecimal128OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>>, DB::detail::NameToDecimal128OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2ffd0d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.869044 [ 5072 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal128OrNull must be constant: In scope SELECT toDecimal128OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./src/Functions/FunctionsConversion.h:2638: DB::detail::FunctionConvertFromString>>, DB::detail::NameToDecimal128OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b2ffd0d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.910261 [ 10341 ] {22cd85c5-8142-4bba-ae33-cac7b1a09ffd} executeQuery: Code: 57. DB::Exception: Table test_pobsq2dx.buf_file already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44526) (comment: 00385_storage_file_and_clickhouse-local_app_long.sh) (query 1, line 1) (in query: CREATE TABLE buf_file ENGINE = File(TSKV) AS SELECT * FROM buf_00385), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.928253 [ 10341 ] {} TCPHandler: Code: 57. DB::Exception: Table test_pobsq2dx.buf_file already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:24:57.950324 [ 29256 ] {138b9735-1b69-4e47-abda-c4a809f7f045} 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.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000017 */ ALTER TABLE rdb_test_11.mt (DROP PARTITION ID 'all'), (UPDATE n = 2 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.092364 [ 29256 ] {138b9735-1b69-4e47-abda-c4a809f7f045} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44512) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.100268 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.186952 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:24:58.279248 [ 2825 ] {c581c4ee-3414-4225-b68c-885b9f16c0ce} executeQuery: Code: 62. DB::Exception: Syntax error (columns declaration list): failed at position 3 (end of query): . Expected one of: NULL, NOT, DEFAULT, MATERIALIZED, EPHEMERAL, ALIAS, AUTO_INCREMENT, PRIMARY KEY, data type, identifier. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44542) (comment: 01256_negative_generate_random.sql) (query 1, line 1) (in query: SELECT * FROM generateRandom('i8', 1, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a7d 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:181: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000002e321d51 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:151: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284e42d5 8. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:156: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284e4a53 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.302695 [ 2825 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error (columns declaration list): failed at position 3 (end of query): . Expected one of: NULL, NOT, DEFAULT, MATERIALIZED, EPHEMERAL, ALIAS, AUTO_INCREMENT, PRIMARY KEY, data type, identifier. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a7d 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:181: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000002e321d51 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:151: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284e42d5 8. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:156: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284e4a53 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.399398 [ 2825 ] {94562a88-a433-43d0-b1a8-8258e46abbc4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'generateRandom' in scope SELECT * FROM generateRandom. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44542) (comment: 01256_negative_generate_random.sql) (query 2, line 2) (in query: SELECT * FROM generateRandom;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.410445 [ 2825 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'generateRandom' in scope SELECT * FROM generateRandom. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.479373 [ 6951 ] {4a557ec0-895d-4d0d-8f53-f7c710c1b838} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44598) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.518318 [ 33000 ] {cd37ecf4-3a55-42ca-a0cf-456cc0d53333} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44432) (comment: 03088_analyzer_ambiguous_column_multi_call.sql) (query 2, line 4) (in query: DROP DATABASE IF EXISTS test_7), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.538115 [ 2825 ] {aaa489a0-44f9-404a-9f96-1ebbdc07cb71} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44542) (comment: 01256_negative_generate_random.sql) (query 3, line 3) (in query: SELECT * FROM generateRandom('i8 UInt8', 1, 10, 10, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000284e3cb8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.544451 [ 33000 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.569698 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.570428 [ 2825 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000284e3cb8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.650094 [ 2825 ] {92486abc-3a4b-44e5-b9ed-13a36941344f} executeQuery: Code: 62. DB::Exception: Empty query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44542) (comment: 01256_negative_generate_random.sql) (query 4, line 4) (in query: SELECT * FROM generateRandom('', 1, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a7d 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:181: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000002e321d51 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:151: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284e42d5 8. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:156: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284e4a53 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.656583 [ 2825 ] {} TCPHandler: Code: 62. DB::Exception: Empty query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a7d 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:181: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000002e321d51 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:151: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000284e42d5 8. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:156: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284e4a53 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.927360 [ 5971 ] {708835d5-7201-4a9b-b346-124581da87c5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47194) (comment: 02375_analyzer_union.sql) (query 1, line 1) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:58.953016 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:24:59.938473 [ 5476 ] {7682841d-89f3-468c-940f-96fa3644a9aa} executeQuery: Code: 524. DB::Exception: Cannot ALTER column: Cannot apply mutation because it breaks projection p1. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02920_alter_column_of_projections.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_76gwyivt.t (MODIFY COLUMN `age` Nullable(Int32))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1322: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d1b3d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.019543 [ 4938 ] {5632c484-b90e-4225-b18b-0085ea7e3b94} 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.3.20372.altinityantalya (altinity build)) (from [::1]:47286) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.031399 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.051508 [ 5476 ] {7682841d-89f3-468c-940f-96fa3644a9aa} executeQuery: Code: 524. DB::Exception: Cannot ALTER column: Cannot apply mutation because it breaks projection p1. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44590) (comment: 02920_alter_column_of_projections.sql) (query 4, line 7) (in query: -- Cannot ALTER, which breaks key column of projection. ALTER TABLE t MODIFY COLUMN age Nullable(Int32);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1322: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d1b3d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.055794 [ 5476 ] {} TCPHandler: Code: 524. DB::Exception: Cannot ALTER column: Cannot apply mutation because it breaks projection p1. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1322: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d1b3d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.272163 [ 4938 ] {fe11aecd-77ce-49a3-8015-7f9eae7ab402} 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.3.20372.altinityantalya (altinity build)) (from [::1]:47286) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.310817 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:00.338399 [ 3816 ] {8770db63-3273-49f1-9438-f5868e6cf3a1} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:52652) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.345602 [ 3816 ] {8770db63-3273-49f1-9438-f5868e6cf3a1} 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]:52652). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:00.353560 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.381254 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.445800 [ 5476 ] {a437e86d-1a25-4f80-bd32-912372c40549} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(uniq, Int16) to AggregateFunction(uniq, Int32) is not supported: While processing _CAST(`uniq(i)`, 'AggregateFunction(uniq, Int32)') AS `uniq(i)`: Cannot apply mutation because it breaks projection p1. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02920_alter_column_of_projections.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_76gwyivt.t (MODIFY COLUMN `i` Int32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb18647 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 18. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002e2d7fa7 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2d797b 20. ./build_docker/./src/Storages/AlterCommands.cpp:1325: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d14c6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 26. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 27. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 28. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 29. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 30. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 31. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 2025.07.13 02:25:00.488834 [ 5476 ] {a437e86d-1a25-4f80-bd32-912372c40549} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(uniq, Int16) to AggregateFunction(uniq, Int32) is not supported: While processing _CAST(`uniq(i)`, 'AggregateFunction(uniq, Int32)') AS `uniq(i)`: Cannot apply mutation because it breaks projection p1. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44590) (comment: 02920_alter_column_of_projections.sql) (query 5, line 10) (in query: -- Cannot ALTER, uniq(Int16) is not compatible with uniq(Int32). ALTER TABLE t MODIFY COLUMN i Int32;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb18647 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 18. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002e2d7fa7 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2d797b 20. ./build_docker/./src/Storages/AlterCommands.cpp:1325: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d14c6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 26. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 27. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 28. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 29. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 30. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 31. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 2025.07.13 02:25:00.491383 [ 5476 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(uniq, Int16) to AggregateFunction(uniq, Int32) is not supported: While processing _CAST(`uniq(i)`, 'AggregateFunction(uniq, Int32)') AS `uniq(i)`: Cannot apply mutation because it breaks projection p1. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb18647 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 18. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002e2d7fa7 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2d797b 20. ./build_docker/./src/Storages/AlterCommands.cpp:1325: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d14c6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 26. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 27. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 28. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 29. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 30. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 31. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 2025.07.13 02:25:00.709699 [ 5379 ] {1931a71b-852e-4730-b9e7-83c6f94cf80c} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:52654) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.712286 [ 3885 ] {80d6d3b8-6689-440d-9000-8a6d5699e821} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41838) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.723360 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.727402 [ 4938 ] {096e1ae1-d5d6-4d7a-b5f0-12542725497f} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47286) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:00.820408 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.823565 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.957293 [ 6951 ] {d259dca2-9617-4e7b-9892-191002152b41} executeQuery: Code: 57. DB::Exception: Table test_13.table_map_with_key_integer already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47242) (comment: 01720_type_map_and_casts.sql) (query 10, line 18) (in query: CREATE TABLE table_map_with_key_integer (`d` DATE, `m` Map(Int32, UInt16)) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 36375, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 61, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 324572918, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 2242363, merge_max_block_size = 13060, old_parts_lifetime = 53., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 118829, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6192673, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 34, 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 = 25904, primary_key_compress_block_size = 45274, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:00.975539 [ 6951 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.table_map_with_key_integer already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.083406 [ 3885 ] {b325502b-62a7-46b4-87a8-fc7b85d6a417} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:52666) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.103540 [ 32979 ] {9e4522d2-492e-43a2-91e1-8187d4286231} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41852) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.110816 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.123019 [ 4938 ] {83a58505-7e30-4f8e-9ce8-a364ead14611} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47286) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:01.130918 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.138677 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.393656 [ 32979 ] {7a44e65c-073c-4dd7-95f6-27f4b32c2134} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:52668) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.399932 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.447498 [ 4938 ] {e4e224f0-a274-4a29-a40f-049aa31b2e33} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47286) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:01.456046 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.472227 [ 6951 ] {d8a41b1a-901d-4f7f-adf7-85eef02e0bdd} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41860) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.488168 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.570030 [ 6126 ] {5fc2eb8c-dd5a-4a7d-918e-cbff54449ee2} executeQuery: Code: 57. DB::Exception: Table test_az2mbsvi.r2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47348) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 1) (in query: ATTACH TABLE r2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:01.577235 [ 6126 ] {} TCPHandler: Code: 57. DB::Exception: Table test_az2mbsvi.r2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.731778 [ 29256 ] {398e3d76-1617-42da-8b63-a5f20e2f04b9} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000018 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.531991119 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47198) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt update n=2 where n=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.742159 [ 29256 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000018 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.531991119 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.743041 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.743757 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.754187 [ 6126 ] {82b1fb4cb8d6447c278538a4d82a4e76-7} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47386) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.763439 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.764608 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.774248 [ 6126 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.774924 [ 4938 ] {82b1fb4cb8d6447c278538a4d82a4e76-10} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47418) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.777396 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.777961 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.778648 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.778759 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.781708 [ 4938 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.781887 [ 34261 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.782738 [ 34261 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.786847 [ 10341 ] {82b1fb4cb8d6447c278538a4d82a4e76-6} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47488) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.787336 [ 6951 ] {82b1fb4cb8d6447c278538a4d82a4e76-4} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47402) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.787973 [ 32979 ] {82b1fb4cb8d6447c278538a4d82a4e76-1} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47428) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.807146 [ 10341 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.808406 [ 32979 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.811797 [ 6951 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.870008 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.870755 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.880729 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.881881 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.886097 [ 7056 ] {82b1fb4cb8d6447c278538a4d82a4e76-3} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47468) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.887890 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.888136 [ 5379 ] {82b1fb4cb8d6447c278538a4d82a4e76-5} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47442) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.896448 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.902710 [ 7056 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.908139 [ 5379 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.927687 [ 3885 ] {82b1fb4cb8d6447c278538a4d82a4e76-9} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47436) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.934843 [ 3885 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.974294 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.975149 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.977947 [ 2825 ] {82b1fb4cb8d6447c278538a4d82a4e76-8} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47486) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:02.980135 [ 6951 ] {ad9c6b29-53a2-49ca-aeaa-b7fb42b8c949} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47504) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (query 1, line 2) (in query: DROP TABLE IF EXISTS r1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.990199 [ 2825 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.990595 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.991265 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:02.995619 [ 33006 ] {82b1fb4cb8d6447c278538a4d82a4e76-2} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47492) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.004654 [ 6951 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.013363 [ 33006 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.019405 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:03.026360 [ 33000 ] {bef9cb38-7095-49b1-8b2c-0056142756a8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(x, 1500000) :: 4) -> throwIf(equals(x, 1500000)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47454) (comment: 00995_exception_while_insert.sh) (query 1, line 1) (in query: INSERT INTO check(x) FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 20. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 21. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.043081 [ 5379 ] {49146da3-865e-4653-aa15-8f65b6449890} executeQuery: Code: 46. DB::Exception: Function with name `plu` does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47508) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT plu(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.050119 [ 33000 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(x, 1500000) :: 4) -> throwIf(equals(x, 1500000)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 20. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 21. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.063171 [ 5379 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `plu` does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.226073 [ 6951 ] {73f5a69c-65db-4224-8e04-92b13fdc3f55} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48048) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_az2mbsvi SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.233044 [ 6951 ] {73f5a69c-65db-4224-8e04-92b13fdc3f55} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:03.573278 [ 2825 ] {82b1fb4cb8d6447c278538a4d82a4e76-15} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.39 MiB (attempt to allocate chunk of 1.39 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47568) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b63c7e 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:121: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x0000000023caca8f 12. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cace55 13. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314a6f61 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314a6f0e 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149e05e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x000000003149deba 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147ddc4 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314b0944 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.591619 [ 2825 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.39 MiB (attempt to allocate chunk of 1.39 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b63c7e 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:121: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x0000000023caca8f 12. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cace55 13. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314a6f61 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314a6f0e 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149e05e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x000000003149deba 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147ddc4 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314b0944 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.665679 [ 34272 ] {b814116e-bbd0-44cf-969e-ffb0915c3491} executeQuery: Code: 46. DB::Exception: Function with name `uniqExac` does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47608) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.675832 [ 34272 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqExac` does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.680183 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.681202 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.686848 [ 5379 ] {82b1fb4cb8d6447c278538a4d82a4e76-13} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47526) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.711856 [ 5379 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.738844 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.749342 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.834454 [ 5105 ] {82b1fb4cb8d6447c278538a4d82a4e76-12} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47548) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.878797 [ 5105 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.935308 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.936708 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.958249 [ 3885 ] {82b1fb4cb8d6447c278538a4d82a4e76-18} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47524) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.966057 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.968148 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.969781 [ 3885 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.976190 [ 33000 ] {82b1fb4cb8d6447c278538a4d82a4e76-16} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47534) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:03.977274 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.978150 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.979972 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:03.982234 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.019768 [ 29256 ] {82b1fb4cb8d6447c278538a4d82a4e76-19} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47590) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.020910 [ 10341 ] {82b1fb4cb8d6447c278538a4d82a4e76-14} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47570) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.028246 [ 33000 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.049027 [ 10341 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.117154 [ 29256 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.119394 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.122028 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.150368 [ 6126 ] {82b1fb4cb8d6447c278538a4d82a4e76-11} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47580) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.156334 [ 6126 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.205237 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.207427 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.210293 [ 32979 ] {82b1fb4cb8d6447c278538a4d82a4e76-17} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47564) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.211615 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.212708 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.220606 [ 32979 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.232633 [ 34261 ] {82b1fb4cb8d6447c278538a4d82a4e76-20} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47592) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.250637 [ 34261 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.666787 [ 3900 ] {40ef6a3d-d318-4f3b-b1af-2e5c3e4e29a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=851). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42024) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: SELECT 1 AS `1`, `__table1`.`n` AS `n` FROM `rdb_test_11`.`rmt` AS `__table1` ORDER BY `__table1`.`n` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.691127 [ 3900 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=851). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.803008 [ 33000 ] {dad977d0-2f8c-496b-9cba-1be7cdc615e2} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=851). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47636) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: select 1, * from rdb_test_11.rmt order by n), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.814654 [ 33000 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=851). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.898226 [ 34261 ] {114787e0-0798-4d7c-b3e5-33aa9538f45e} executeQuery: Code: 46. DB::Exception: Function with name `test_user_defined_function_test_13A` does not exist. In scope SELECT test_user_defined_function_test_13A(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_13']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47722) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT test_user_defined_function_test_13A(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.906995 [ 34261 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `test_user_defined_function_test_13A` does not exist. In scope SELECT test_user_defined_function_test_13A(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_13']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.917605 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.918077 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.918816 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.919765 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.923762 [ 34260 ] {82b1fb4cb8d6447c278538a4d82a4e76-26} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47670) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.925452 [ 34259 ] {82b1fb4cb8d6447c278538a4d82a4e76-24} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47656) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.926421 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.932361 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.959834 [ 29256 ] {82b1fb4cb8d6447c278538a4d82a4e76-27} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47686) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:04.960517 [ 34260 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.961395 [ 34259 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:04.988123 [ 29256 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.045913 [ 2825 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.047494 [ 2825 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.060249 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.061061 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.061196 [ 34273 ] {82b1fb4cb8d6447c278538a4d82a4e76-22} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47684) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.080021 [ 7056 ] {82b1fb4cb8d6447c278538a4d82a4e76-30} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47688) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.082183 [ 34273 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.097521 [ 7056 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.103217 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.104940 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.124247 [ 34272 ] {82b1fb4cb8d6447c278538a4d82a4e76-29} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47682) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.125914 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.126848 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.137543 [ 34272 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.139378 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.140694 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.143530 [ 34340 ] {82b1fb4cb8d6447c278538a4d82a4e76-21} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47690) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.153527 [ 34340 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.216561 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.217395 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.224150 [ 34268 ] {82b1fb4cb8d6447c278538a4d82a4e76-28} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47676) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.237985 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.238917 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.240718 [ 34268 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.242419 [ 5379 ] {82b1fb4cb8d6447c278538a4d82a4e76-23} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47712) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.264512 [ 5379 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.265360 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.266893 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.272583 [ 2824 ] {fb98e4c4-91f1-427e-8305-1cf465bd47dc} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02155_dictionary_comment.sql) (in query: /* ddl_entry=query-0000000166 */ ALTER TABLE test_5.`02155_test_dictionary` (COMMENT COLUMN value 'value_column')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.283850 [ 32979 ] {82b1fb4cb8d6447c278538a4d82a4e76-25} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47698) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:05.323354 [ 32979 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.354898 [ 2824 ] {fb98e4c4-91f1-427e-8305-1cf465bd47dc} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47490) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.357883 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.538487 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:05.926077 [ 10341 ] {e2f24a04-8f56-4077-b892-c6d200a09f7d} executeQuery: Code: 46. DB::Exception: Function with name `lambda_functio` does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47868) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: WITH (x -> x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:05.963804 [ 10341 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `lambda_functio` does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.012355 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.014295 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.018236 [ 7056 ] {82b1fb4cb8d6447c278538a4d82a4e76-32} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47790) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.018689 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.020164 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.033707 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.034629 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.036201 [ 7056 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.045096 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.049143 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.058426 [ 29256 ] {82b1fb4cb8d6447c278538a4d82a4e76-38} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47774) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.076097 [ 4938 ] {82b1fb4cb8d6447c278538a4d82a4e76-37} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47800) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.099351 [ 4938 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.132514 [ 3816 ] {82b1fb4cb8d6447c278538a4d82a4e76-31} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47758) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.138679 [ 3816 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.158907 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.167442 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.170479 [ 29256 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.171756 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.172430 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.181745 [ 34272 ] {82b1fb4cb8d6447c278538a4d82a4e76-35} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47754) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.190036 [ 5105 ] {82b1fb4cb8d6447c278538a4d82a4e76-39} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47814) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.215385 [ 5105 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.220331 [ 34272 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.391642 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.392823 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.393691 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.394673 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.396993 [ 2825 ] {82b1fb4cb8d6447c278538a4d82a4e76-40} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47830) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.417515 [ 2825 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.442444 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.443624 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.449432 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.452651 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.489725 [ 34261 ] {82b1fb4cb8d6447c278538a4d82a4e76-33} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47836) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.502133 [ 33000 ] {82b1fb4cb8d6447c278538a4d82a4e76-34} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47852) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.506622 [ 34261 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.514216 [ 34273 ] {82b1fb4cb8d6447c278538a4d82a4e76-36} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:53206 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47770) (comment: 01455_opentelemetry_distributed.sh) (query 1, line 1) (in query: select 1 from remote('127.0.0.2', system, one) format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148f8bf 7. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x0000000031492d65 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314d3c5d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314d361e 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3c42f5 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3c207d 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:06.520603 [ 33000 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.555224 [ 34273 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:53206 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148f8bf 7. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x0000000031492d65 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314d3c5d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314d361e 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3c42f5 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3c207d 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.574590 [ 33006 ] {168e97c6-a718-4fef-9006-2ef76d3805ea} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47894) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000028d689cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3fcbb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:06.597263 [ 33006 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000028d689cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3fcbb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:07.469569 [ 34259 ] {6be5fd36-4e69-4d25-9df7-b87509bcc038} executeQuery: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47928) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x0000000032e93089 6. ./build_docker/./src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000032f9e985 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ac5e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 9. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000303932de 10. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000030390461 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageDistributed* std::construct_at[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, DB::StorageDistributed*>(DB::StorageDistributed*, 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&&) @ 0x0000000028498db1 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, std::allocator, 0>(std::allocator, 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&&) @ 0x0000000028498933 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000028498727 14. ./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 @ 0x0000000028492770 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:25:07.508798 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x0000000032e93089 6. ./build_docker/./src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000032f9e985 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ac5e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 9. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000303932de 10. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000030390461 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageDistributed* std::construct_at[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, DB::StorageDistributed*>(DB::StorageDistributed*, 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&&) @ 0x0000000028498db1 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, std::allocator, 0>(std::allocator, 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&&) @ 0x0000000028498933 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000028498727 14. ./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 @ 0x0000000028492770 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:25:08.235618 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:08.910382 [ 5072 ] {b5792ac6-8b11-4cba-9095-6cfde9b1a3cc} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000019 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.071992275 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47732) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:08.931646 [ 5072 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000019 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.071992275 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:09.834784 [ 34268 ] {56191201-628e-4a97-899e-b16600f66123} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:09.888949 [ 34268 ] {56191201-628e-4a97-899e-b16600f66123} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47960) (comment: 03082_analyzer_left_join_correct_column.sql) (query 6, line 23) (in query: SELECT t1.pk, t2.x.y FROM test1 t1 LEFT JOIN test2 t2 on t1.pk = t2.pk;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:09.931901 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:25:10.710372 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:10.719974 [ 2824 ] {ea5b846f-4e11-4c1a-9dc5-0c034ae4ba25} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02155_dictionary_comment.sql) (in query: /* ddl_entry=query-0000000170 */ ALTER TABLE test_5.`02155_test_dictionary_view` (COMMENT COLUMN value 'value_column')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:10.780455 [ 3885 ] {d65b19b3-5d2b-4b55-a63e-ac5b45d0bbac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47700) (comment: 03164_materialize_skip_index.sql) (query 20, line 39) (in query: SELECT count() FROM t_skip_index_insert WHERE a >= 110 AND a < 130 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:25:10.806064 [ 3885 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:10.810997 [ 2824 ] {ea5b846f-4e11-4c1a-9dc5-0c034ae4ba25} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47490) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:10.815116 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:12.255809 [ 34261 ] {daa77614-f869-4211-a846-6e33f744ec52} executeQuery: Code: 572. DB::Exception: Too many optimizations applied to query plan. Current limit 1. (TOO_MANY_QUERY_PLAN_OPTIMIZATIONS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43826) (comment: 01655_plan_optimizations.sh) (query 1, line 1) (in query: select x + 1 from (select y + 2 as x from (select dummy + 3 as y)) settings query_plan_max_optimizations_to_apply = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:87: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032288ccd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddd4 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:12.271524 [ 34261 ] {} TCPHandler: Code: 572. DB::Exception: Too many optimizations applied to query plan. Current limit 1. (TOO_MANY_QUERY_PLAN_OPTIMIZATIONS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:87: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032288ccd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddd4 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:12.932807 [ 33000 ] {57b8f246-00eb-43c1-8509-55b38f9e570d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43856) (comment: 01825_type_json_nullable.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:12.955391 [ 33000 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:13.029808 [ 3900 ] {4d03c9f5-5c8d-489c-be92-5632878bcb7d} executeQuery: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43852) (comment: 02023_nullable_int_uint_where.sql) (query 3, line 4) (in query: CREATE TABLE t1 (`id` LowCardinality(Nullable(Int64))) ENGINE = MergeTree ORDER BY id SETTINGS allow_nullable_key = 1, index_granularity = 1, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.017065562307834625, 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 = 301420181, compact_parts_max_granules_to_buffer = 211, compact_parts_merge_max_bytes_to_prefetch_part = 18737736, merge_max_block_size = 23825, old_parts_lifetime = 48., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 79, min_merge_bytes_to_use_direct_io = 2143548637, index_granularity_bytes = 3432178, 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 = 12917, primary_key_compress_block_size = 62448, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:13.037194 [ 3900 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:13.105390 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:14.580676 [ 33000 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:14.588949 [ 33000 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:14.758043 [ 34273 ] {90fba256-e320-450c-8cc4-2bef69203b93} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 16, line 50) (in query: -- shall not work for month, quarter, year (intervals with floating number of seconds) -- Month SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 11 MONTH) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6644 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:14.782216 [ 34273 ] {} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6644 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:14.887927 [ 34273 ] {65151fed-47ac-4626-b484-83620bcd4238} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 17, line 53) (in query: -- Quarter SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 12 QUARTER) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6644 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:14.938078 [ 34273 ] {} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6644 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:15.097442 [ 5105 ] {51735ee7-c39b-42c0-8c00-326b847975b8} test_9.table_one (e36e4ceb-de7a-4f97-8061-7b378cca9598): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:25:15.124990 [ 34273 ] {0e87c677-c137-47f2-ad7a-88a70dca9185} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 18, line 55) (in query: -- Year SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 13 YEAR) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6644 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:15.132138 [ 34273 ] {} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6644 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:15.267103 [ 4938 ] {76447856-5232-4077-94d5-87fb97d2225e} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.543991089 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43794) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:15.284235 [ 4938 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_11/rdb/log/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.543991089 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df16317 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6246fb 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:15.391906 [ 34340 ] {7a4dc5f3-949a-4c01-8dc5-603635d24bed} executeQuery: Code: 36. DB::Exception: TTL expression defaultProfiles() does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43946) (comment: 03362_default_profiles_context.sql) (query 1, line 1) (in query: CREATE TEMPORARY TABLE t0 (`c0` Int TTL defaultProfiles()) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 1493, min_bytes_for_wide_part = 176850158, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 10, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 423405797, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 22706958, merge_max_block_size = 19203, old_parts_lifetime = 121., prefer_fetch_merged_part_size_threshold = 7769431620, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 312804223, index_granularity_bytes = 12997204, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 67430, primary_key_compress_block_size = 14646, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c14f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c7f7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000002dc95bc7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d5f00af 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc86851 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:25:15.399863 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression defaultProfiles() 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c14f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c7f7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000002dc95bc7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d5f00af 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc86851 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:25:15.482410 [ 34340 ] {070ee7a4-12eb-4406-a178-c16f765a04ac} executeQuery: Code: 36. DB::Exception: TTL expression defaultRoles() does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43946) (comment: 03362_default_profiles_context.sql) (query 2, line 2) (in query: CREATE TEMPORARY TABLE t0 (`c0` Int TTL defaultRoles()) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 1493, min_bytes_for_wide_part = 176850158, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 10, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 423405797, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 22706958, merge_max_block_size = 19203, old_parts_lifetime = 121., prefer_fetch_merged_part_size_threshold = 7769431620, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 312804223, index_granularity_bytes = 12997204, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 67430, primary_key_compress_block_size = 14646, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c14f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c7f7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000002dc95bc7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d5f00af 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc86851 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:25:15.495035 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression defaultRoles() 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003082c14f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c7f7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000002dc95bc7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d5f00af 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc86851 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:25:15.508208 [ 34273 ] {20658909-e7a8-4ac8-8646-a5a4525caa67} executeQuery: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 19, line 58) (in query: -- test against wrong arguments/types SELECT ts, metric, nonNegativeDerivative(metric, 1, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2533: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6281 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:15.545350 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2533: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6281 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:15.787214 [ 34273 ] {924bbe04-a1dd-406e-96e1-52786080f857} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 20, line 60) (in query: SELECT ts, metric, nonNegativeDerivative('string not datetime', ts, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2525: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef616b 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:15.790399 [ 7213 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:15.803400 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2525: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef616b 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:16.000611 [ 34273 ] {6364581e-39d9-44b8-9ecf-5179526b3600} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 21, line 61) (in query: SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 3 NANOSECOND, id) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6054 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:16.007372 [ 34273 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6054 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:16.155865 [ 34273 ] {c77b8741-1a64-4acd-9c37-3cc36db54f5a} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 02346_non_negative_derivative.sql) (query 22, line 62) (in query: SELECT ts, metric, nonNegativeDerivative(metric) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6054 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:16.175365 [ 34273 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef6054 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef5bc0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef56d9 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000031ef54ec 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000031ed0045 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38270 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:25:16.400760 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:16.405089 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:17.109948 [ 5105 ] {0a1278ea-e994-469d-9eca-9f8fb7d1a070} test_9.table_one (ba9792e2-3a6b-4f83-8ef9-af0faea25711): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:25:17.485234 [ 5105 ] {0b8076f0-ceb0-4d55-acb6-fb7df8fdf0de} executeQuery: Code: 57. DB::Exception: Table test_9.table_two already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43910) (comment: 02422_insert_different_granularity.sql) (query 12, line 33) (in query: CREATE TABLE table_two (`id` UInt64, `value` UInt64) ENGINE = MergeTree PARTITION BY id ORDER BY value SETTINGS index_granularity = 8192, index_granularity_bytes = 0, min_bytes_for_wide_part = 100, ratio_of_defaults_for_sparse_serialization = 0.839116096496582, replace_long_file_name_to_hash = true, max_file_name_length = 52, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 303923247, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 21252067, merge_max_block_size = 18656, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1310426912, vertical_merge_algorithm_min_rows_to_activate = 390292, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, 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 = 58088, primary_key_compress_block_size = 75444, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:17.505596 [ 5105 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.table_two already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:17.955461 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:17.957112 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:18.270293 [ 34275 ] {565d49e5-b4ce-45ff-9786-60a6fc4cc3e1} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44156) (comment: 03273_group_by_in_order_still_used_when_group_by_key_doesnt_match_order_by_key.sql) (query 1, line 1) (in query: CREATE TABLE test (`a` UInt64, `b` UInt64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 12336, min_bytes_for_wide_part = 1073741824, 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 = 327115035, compact_parts_max_bytes_to_buffer = 278210617, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 4604856, merge_max_block_size = 11276, old_parts_lifetime = 217., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 356276, vertical_merge_algorithm_min_columns_to_activate = 11, min_merge_bytes_to_use_direct_io = 6632424782, index_granularity_bytes = 1525548, 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 = false, marks_compress_block_size = 12888, primary_key_compress_block_size = 73475, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:18.299933 [ 34275 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:18.623533 [ 5476 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:631: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc1a6ca 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3874: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10619 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:25:19.189518 [ 34340 ] {a38f1640-41f3-49ab-89c3-daa451ab9c86} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float64, UInt64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT ifNotFinite(12345678901234567890, -12345678901234567000.). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44132) (comment: 01065_if_not_finite.sql) (query 8, line 9) (in query: SELECT ifNotFinite(12345678901234567890, -12345678901234567890);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. DB::(anonymous namespace)::FunctionIfNotFinite::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c1cffaf 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:25:19.213141 [ 34340 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float64, UInt64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT ifNotFinite(12345678901234567890, -12345678901234567000.). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. DB::(anonymous namespace)::FunctionIfNotFinite::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c1cffaf 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:25:19.281296 [ 34272 ] {ec477bc9-a421-49d7-a700-5ce81ec0f60b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43706) (comment: 02540_date_column_consistent_insert_behaviour.sql) (query 53, line 73) (in query: SELECT x, txt FROM 02540_date WHERE txt == 'CAST(65534 as UInt16)';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:19.304035 [ 34272 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:19.385454 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:19.388103 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:20.641173 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:20.642016 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:20.737969 [ 34260 ] {88ec95a0-9fde-4e28-9166-18b073562c98} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40468) (comment: 03355_array_join_subcolumns.sql) (query 3, line 6) (in query: create table test (arr Array(UInt64), t Tuple(a Array(UInt32), b Array(UInt32))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:20.760755 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:21.079305 [ 4529 ] {068cfbef-2751-48dd-a5b8-448c390c44fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=846). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40404) (comment: 02864_statistics_bug_69589.sql) (query 9, line 13) (in query: SELECT 1 FROM tab WHERE tab.c = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:21.096571 [ 4529 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=903, jobs=846). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:21.252252 [ 33006 ] {313ce6ef-4f12-49a1-af90-5b47cae32dd4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48988) (comment: 02864_statistics_bug_69589.sql) (in query: DROP DATABASE IF EXISTS test_23sjq4m2 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:21.260083 [ 33006 ] {313ce6ef-4f12-49a1-af90-5b47cae32dd4} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:21.369258 [ 3885 ] {4cf780f6-e263-4f0e-8083-afeefa05631e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40528) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: drop database rdb_test_11), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:21.382407 [ 3885 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:22.057339 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:22.064331 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:23.307180 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:23.308206 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:23.355531 [ 5971 ] {8451354b-6507-45da-acbc-45a448c505a9} executeQuery: Code: 82. DB::Exception: Database rdb_test_11 already exists. (DATABASE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40642) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: create database rdb_test_11 engine=Replicated('/test/test_11/rdb', 's1', 'r1')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:204: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc5c5ed 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:23.409538 [ 5971 ] {} TCPHandler: Code: 82. DB::Exception: Database rdb_test_11 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:204: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc5c5ed 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:23.678845 [ 7056 ] {767645ab-8e6c-45ef-a46a-e1ae3ace31ae} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49072) (comment: 02923_cte_equality_disjunction.sql) (in query: DROP DATABASE IF EXISTS test_z4lwgxey SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:23.696661 [ 7056 ] {767645ab-8e6c-45ef-a46a-e1ae3ace31ae} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:24.019079 [ 3766 ] {02d900ca-aa32-40b9-82b0-720e579c7603} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40682) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: CREATE TABLE rdb_test_11.mt (`n` int) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 10592, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 393354568, compact_parts_max_bytes_to_buffer = 401148602, compact_parts_max_granules_to_buffer = 50, compact_parts_merge_max_bytes_to_prefetch_part = 19041157, merge_max_block_size = 18774, old_parts_lifetime = 377., prefer_fetch_merged_part_size_threshold = 6654921503, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5149027795, index_granularity_bytes = 15532015, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 22, 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 = 92516, primary_key_compress_block_size = 60069, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:24.066197 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:24.487698 [ 5105 ] {1cc1abec-4452-480d-b649-89829e352d01} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40716) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: CREATE TABLE rdb_test_11.rmt (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 10592, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 393354568, compact_parts_max_bytes_to_buffer = 401148602, compact_parts_max_granules_to_buffer = 50, compact_parts_merge_max_bytes_to_prefetch_part = 19041157, merge_max_block_size = 18774, old_parts_lifetime = 377., prefer_fetch_merged_part_size_threshold = 6654921503, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5149027795, index_granularity_bytes = 15532015, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 22, 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 = 92516, primary_key_compress_block_size = 60069, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:24.509322 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.077294 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.085028 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.158045 [ 34260 ] {fd9440c8-c53b-42d9-94a8-33cba9d25298} executeQuery: Code: 57. DB::Exception: Table test_dvjmam9x.errors_local already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02133_final_prewhere_where_lowcardinality_replacing.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_dvjmam9x.errors_local UUID '5ed1da1c-7dc2-4150-95de-1070ba699e90' (`level` LowCardinality(String)) ENGINE = ReplacingMergeTree ORDER BY level SETTINGS index_granularity = 37883, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 94, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 434688461, compact_parts_max_granules_to_buffer = 139, compact_parts_merge_max_bytes_to_prefetch_part = 4925567, merge_max_block_size = 15491, old_parts_lifetime = 132., 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 = 647788222, index_granularity_bytes = 1464602, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 26, 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 = 45955, primary_key_compress_block_size = 29696, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.177434 [ 34260 ] {fd9440c8-c53b-42d9-94a8-33cba9d25298} executeQuery: Code: 57. DB::Exception: Table test_dvjmam9x.errors_local already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40648) (comment: 02133_final_prewhere_where_lowcardinality_replacing.sql) (query 6, line 10) (in query: CREATE TABLE errors_local (`level` LowCardinality(String)) ENGINE = ReplacingMergeTree ORDER BY level SETTINGS index_granularity = 37883, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 94, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 434688461, compact_parts_max_granules_to_buffer = 139, compact_parts_merge_max_bytes_to_prefetch_part = 4925567, merge_max_block_size = 15491, old_parts_lifetime = 132., 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 = 647788222, index_granularity_bytes = 1464602, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 26, 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 = 45955, primary_key_compress_block_size = 29696, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.182731 [ 3766 ] {6d7f026f-0b37-4a5b-a783-f8c31f1f35c2} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/s1/replicas/r1. (TABLE_IS_READ_ONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40736) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: insert into rdb_test_11.rmt values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000031193c69 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003119067d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x00000000311904ed 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: 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'()&&) @ 0x0000000031190158 9. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000031175bcc 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003115fb50 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031174fa1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc48c1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 18. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 19. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.184951 [ 34260 ] {} TCPHandler: Code: 57. DB::Exception: Table test_dvjmam9x.errors_local already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.227365 [ 3766 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/s1/replicas/r1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000031193c69 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003119067d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x00000000311904ed 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: 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'()&&) @ 0x0000000031190158 9. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000031175bcc 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003115fb50 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031174fa1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc48c1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 18. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 19. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.569736 [ 3766 ] {cb22cb7f-7578-4bed-a551-352530f79ac8} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40770) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: insert into rdb_test_11.mt values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:25.592942 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:26.291933 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:26.294047 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:26.493635 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:26.769506 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:26.817969 [ 5105 ] {630c644c-b62b-4f3b-a6e7-c5fdcc225e34} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int64, UInt32)' because variants 'Int64' and 'UInt32' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Int64' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt32, Int64)'). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40826) (comment: 02999_variant_suspicious_types.sql) (query 2, line 2) (in query: select 42::Variant(UInt32, Int64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:26.834799 [ 5105 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int64, UInt32)' because variants 'Int64' and 'UInt32' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Int64' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt32, Int64)'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:26.893211 [ 5105 ] {49421f38-c27d-4b63-842a-1f290e02c2e3} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Array(Int64), Array(UInt32))' because variants 'Array(Int64)' and 'Array(UInt32)' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Array(Int64)' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('[42]', 'Variant(Array(UInt32), Array(Int64))'). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40826) (comment: 02999_variant_suspicious_types.sql) (query 3, line 3) (in query: select [42]::Variant(Array(UInt32), Array(Int64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:26.897591 [ 5105 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Array(Int64), Array(UInt32))' because variants 'Array(Int64)' and 'Array(UInt32)' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Array(Int64)' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('[42]', 'Variant(Array(UInt32), Array(Int64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:26.959380 [ 5105 ] {117a85fb-a43d-425a-b624-cac660bb705a} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(LowCardinality(String), String)' because variants 'LowCardinality(String)' and 'String' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'String' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('Hello', 'Variant(String, LowCardinality(String))'). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40826) (comment: 02999_variant_suspicious_types.sql) (query 4, line 4) (in query: select 'Hello'::Variant(String, LowCardinality(String));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:26.975114 [ 5105 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(LowCardinality(String), String)' because variants 'LowCardinality(String)' and 'String' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'String' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('Hello', 'Variant(String, LowCardinality(String))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:27.038933 [ 2825 ] {2255754b-e97b-4bbb-b417-df4db8a4af35} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40836) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:27.043301 [ 2825 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:27.059597 [ 5105 ] {ede68f15-8b7c-4999-b2e0-67b5d3faa37b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Tuple(Int64, String), Tuple(UInt32, String))' because variants 'Tuple(Int64, String)' and 'Tuple(UInt32, String)' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Tuple(Int64, String)' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('(1, \'Hello\')', 'Variant(Tuple(UInt32, String), Tuple(Int64, String))'). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40826) (comment: 02999_variant_suspicious_types.sql) (query 5, line 5) (in query: select (1, 'Hello')::Variant(Tuple(UInt32, String), Tuple(Int64, String));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:27.070705 [ 5105 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Tuple(Int64, String), Tuple(UInt32, String))' because variants 'Tuple(Int64, String)' and 'Tuple(UInt32, String)' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Tuple(Int64, String)' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST('(1, \'Hello\')', 'Variant(Tuple(UInt32, String), Tuple(Int64, String))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:27.169114 [ 5105 ] {f01eb894-f426-4d71-8327-b7d2b615cfc8} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Map(UInt64, Int64), Map(UInt64, UInt32))' because variants 'Map(UInt64, Int64)' and 'Map(UInt64, UInt32)' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Map(UInt64, Int64)' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST(map(42, 42), 'Variant(Map(UInt64, UInt32), Map(UInt64, Int64))'). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40826) (comment: 02999_variant_suspicious_types.sql) (query 6, line 6) (in query: select map(42, 42)::Variant(Map(UInt64, UInt32), Map(UInt64, Int64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:27.175675 [ 5105 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Map(UInt64, Int64), Map(UInt64, UInt32))' because variants 'Map(UInt64, Int64)' and 'Map(UInt64, UInt32)' have similar types and working with values of these types may lead to ambiguity. Consider using common single variant 'Map(UInt64, Int64)' instead of these 2 variants or set setting allow_suspicious_variant_types = 1 in order to allow it: In scope SELECT CAST(map(42, 42), 'Variant(Map(UInt64, UInt32), Map(UInt64, Int64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:129: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000002e321016 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000002e31fd40 7. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad5cd84 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:27.615826 [ 34261 ] {d74a149e-65c9-4120-bad2-6e27a3d88d92} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40856) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:27.648087 [ 34261 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:27.997750 [ 33000 ] {8a37fb07-e138-4f99-ada0-8268bc880b98} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40902) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.030945 [ 33000 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.390224 [ 33000 ] {fcb4cecf-e0e0-473e-8bc0-6cd63f495ea9} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40920) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.418233 [ 33000 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.542933 [ 4477 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.543714 [ 4477 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.848263 [ 3900 ] {669564e4-00a3-4b66-8f29-ece2a526ee19} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46936) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:66: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37c19f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:25:28.856866 [ 3900 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:66: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37c19f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:25:29.344438 [ 34261 ] {7fac87c9-230e-4eca-907d-cd7a0f51a26e} 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: In scope SELECT mapContains(a, 10) FROM table_map. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 8, line 9) (in query: select mapContains(a, 10) from table_map;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. DB::FunctionArrayIndex::allowArguments(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000020f07cdf 7. DB::FunctionArrayIndex::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e56c46 8. DB::FunctionMapToArrayAdapter, DB::MapToSubcolumnAdapter, DB::NameMapContains>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e5617a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:29.350110 [ 34261 ] {} 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: In scope SELECT mapContains(a, 10) FROM table_map. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. DB::FunctionArrayIndex::allowArguments(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000020f07cdf 7. DB::FunctionArrayIndex::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e56c46 8. DB::FunctionMapToArrayAdapter, DB::MapToSubcolumnAdapter, DB::NameMapContains>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e5617a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:30.176037 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:30.180115 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:30.204329 [ 5072 ] {cef1a488-31b9-4128-8a7a-701620a0d44b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47012) (comment: 03039_dynamic_aggregating_merge_tree.sh) (query 1, line 1) (in query: select count(), sum from (select sumMerge(sum) as sum from test group by id, _part) group by sum order by sum, count()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:25:30.232441 [ 5072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:30.729386 [ 34261 ] {8a659d8d-717e-4301-8253-78ffe4af32af} 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 mapContains(a, 'aaa') FROM table_map. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 15, line 18) (in query: select mapContains(a, 'aaa') from table_map;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. DB::FunctionArrayIndex::allowArguments(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000020f07cdf 7. DB::FunctionArrayIndex::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e56c46 8. DB::FunctionMapToArrayAdapter, DB::MapToSubcolumnAdapter, DB::NameMapContains>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e5617a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:30.734086 [ 34261 ] {} 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 mapContains(a, 'aaa') FROM table_map. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. DB::FunctionArrayIndex::allowArguments(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000020f07cdf 7. DB::FunctionArrayIndex::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e56c46 8. DB::FunctionMapToArrayAdapter, DB::MapToSubcolumnAdapter, DB::NameMapContains>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e5617a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:30.977103 [ 34261 ] {fa8259fe-e35b-428b-be61-72503f21d57f} executeQuery: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(b, 'aaa') FROM table_map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 16, line 19) (in query: select mapContains(b, 'aaa') from table_map;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::MapAdapterBase, DB::NameMapContains>::extractNestedTypesAndColumns(std::vector>&) @ 0x0000000020f089af 6. DB::MapToSubcolumnAdapter::extractNestedTypesAndColumns(std::vector>&) @ 0x0000000020f08476 7. DB::FunctionMapToArrayAdapter, DB::MapToSubcolumnAdapter, DB::NameMapContains>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e560e5 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:30.987734 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(b, 'aaa') FROM table_map. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000017d1664f 5. DB::MapAdapterBase, DB::NameMapContains>::extractNestedTypesAndColumns(std::vector>&) @ 0x0000000020f089af 6. DB::MapToSubcolumnAdapter::extractNestedTypesAndColumns(std::vector>&) @ 0x0000000020f08476 7. DB::FunctionMapToArrayAdapter, DB::MapToSubcolumnAdapter, DB::NameMapContains>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020e560e5 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:31.044038 [ 34272 ] {348fdca6-1639-482f-91e7-6356c969761c} executeQuery: Code: 57. DB::Exception: Table test_qwvqj3um.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47080) (comment: 03039_dynamic_aggregating_merge_tree.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `sum` AggregateFunction(sum, UInt64), `d` Dynamic) ENGINE = AggregatingMergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000000, min_bytes_for_wide_part = 1000000000000, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 0.1576385796070099, replace_long_file_name_to_hash = true, max_file_name_length = 5, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 90478516, compact_parts_max_granules_to_buffer = 150, compact_parts_merge_max_bytes_to_prefetch_part = 177514, merge_max_block_size = 8128, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 7624600487, index_granularity_bytes = 10485760, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 51, 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 = 24118, primary_key_compress_block_size = 22179, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:31.070590 [ 34272 ] {} TCPHandler: Code: 57. DB::Exception: Table test_qwvqj3um.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:31.579193 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:31.792611 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:31.844067 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:32.660412 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:32.671759 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:33.183783 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:33.945905 [ 32979 ] {4f1ad881-d7e7-4cb3-969c-3200ac3a5878} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=35): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/data.bin (position: 1316920, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: d32958eb9a9f134f606c811683dfcae7828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 20 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47248) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:33.960420 [ 32979 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=35): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/data.bin (position: 1316920, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: d32958eb9a9f134f606c811683dfcae7828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 20 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:34.374049 [ 4529 ] {df4dbdae-fe5b-4b5b-bf4d-ed8493cef7c7} executeQuery: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40560) (comment: 00282_merging.sql) (query 61, line 99) (in query: OPTIMIZE TABLE merge;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311e9234 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:1710: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311f4775 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:34.384749 [ 4529 ] {} TCPHandler: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311e9234 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:1710: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311f4775 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:34.979765 [ 4938 ] {4d434029-3fda-4e96-8637-a340d02b37fb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=31): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/data.bin (position: 2831378, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6b32113617e9b01320b5e33e2ef134af828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 43 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47278) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:34.994547 [ 4938 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=31): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/data.bin (position: 2831378, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6b32113617e9b01320b5e33e2ef134af828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 43 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:35.467166 [ 34261 ] {d21302e1-a3b0-4630-88f1-71ef83555f81} executeQuery: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but String is given: In scope SELECT mapFromArrays('aa', [4, 5]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 41, line 63) (in query: select mapFromArrays('aa', [4, 5]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(std::shared_ptr const&)::operator()(std::shared_ptr const&) const @ 0x000000001dcda481 6. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dcd9871 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:35.478988 [ 4477 ] {1b4d677e-c82e-41df-b52b-00497938d18c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=34). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47424) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000032da38fd 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 17. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 18. ./src/IO/ReadHelpers.h:117: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c60067c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexHypothesis.cpp:38: DB::MergeTreeIndexGranuleHypothesis::deserializeBinary(DB::ReadBuffer&, unsigned char) @ 0x0000000030ed0575 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1674: DB::MergeTreeDataSelectExecutor::filterMarksUsingMergedIndex(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e37847 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:758: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ef58 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:811: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 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)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030e3b4f4 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:25:35.482768 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but String is given: In scope SELECT mapFromArrays('aa', [4, 5]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(std::shared_ptr const&)::operator()(std::shared_ptr const&) const @ 0x000000001dcda481 6. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dcd9871 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:35.521919 [ 4477 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=34). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000032da38fd 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 17. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 18. ./src/IO/ReadHelpers.h:117: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c60067c 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexHypothesis.cpp:38: DB::MergeTreeIndexGranuleHypothesis::deserializeBinary(DB::ReadBuffer&, unsigned char) @ 0x0000000030ed0575 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1674: DB::MergeTreeDataSelectExecutor::filterMarksUsingMergedIndex(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e37847 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:758: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ef58 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:811: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 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)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030e3b4f4 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:25:35.800559 [ 34261 ] {35c88ee0-235f-436e-8058-2bc723f88c03} executeQuery: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but UInt8 is given: In scope SELECT mapFromArrays(['aa', 'bb'], 5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 42, line 64) (in query: select mapFromArrays(['aa', 'bb'], 5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(std::shared_ptr const&)::operator()(std::shared_ptr const&) const @ 0x000000001dcda481 6. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dcd98b4 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:35.808752 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but UInt8 is given: In scope SELECT mapFromArrays(['aa', 'bb'], 5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(std::shared_ptr const&)::operator()(std::shared_ptr const&) const @ 0x000000001dcda481 6. DB::(anonymous namespace)::FunctionMapFromArrays::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dcd98b4 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:35.811612 [ 2824 ] {42de3e0d-caa1-4bab-8be8-93bcea1a20d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=31): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/data.bin (position: 8263673, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 17ddc51c7107736faf1faa426019670f828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 125 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47244) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:35.829127 [ 2824 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=31): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/data.bin (position: 8263673, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 17ddc51c7107736faf1faa426019670f828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 125 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:35.929443 [ 34261 ] {7a9c8ea7-a06a-4c5c-bb96-6221476d2fcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(['aa', 'bb'], [4, 5], [6, 7]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 43, line 65) (in query: select mapFromArrays(['aa', 'bb'], [4, 5], [6, 7]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:25:35.949495 [ 34261 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(['aa', 'bb'], [4, 5], [6, 7]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:25:36.155050 [ 34261 ] {5691282a-45c6-4610-b774-13ab10ea77b3} executeQuery: Code: 190. DB::Exception: Two arguments of function mapFromArrays must have equal sizes: In scope SELECT mapFromArrays(['aa', 'bb'], [4, 5, 6]). (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 44, line 66) (in query: select mapFromArrays(['aa', 'bb'], [4, 5, 6]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd9219 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.161311 [ 34261 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments of function mapFromArrays must have equal sizes: In scope SELECT mapFromArrays(['aa', 'bb'], [4, 5, 6]). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd9219 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.247021 [ 34261 ] {f645ae43-097e-4882-b4f9-47a3fdfde2ba} executeQuery: Code: 190. DB::Exception: Two arguments of function mapFromArrays must have equal sizes: In scope SELECT mapFromArrays([[1, 2], [3, 4]], [4, 5, 6]). (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 45, line 67) (in query: select mapFromArrays([[1,2], [3,4]], [4, 5, 6]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd9219 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.253068 [ 34261 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments of function mapFromArrays must have equal sizes: In scope SELECT mapFromArrays([[1, 2], [3, 4]], [4, 5, 6]). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd9219 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.371971 [ 34261 ] {d4e2f5cb-3268-4715-b17a-dab706a53f0c} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 46, line 68) (in query: select mapFromArrays(['a', 2], [4, 5]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002c4de745 7. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ca94bda 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ConstantNode* std::construct_at[abi:ne190107](DB::ConstantNode*, DB::Field const&) @ 0x000000002cbd0806 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::Field const&) @ 0x000000002cbd06bf 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x000000002cbd053a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba7fc8 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba8af5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 17. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 18. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:36.391024 [ 34261 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002c4de745 7. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ca94bda 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ConstantNode* std::construct_at[abi:ne190107](DB::ConstantNode*, DB::Field const&) @ 0x000000002cbd0806 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::Field const&) @ 0x000000002cbd06bf 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x000000002cbd053a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba7fc8 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba8af5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 17. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 18. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:36.464013 [ 34261 ] {72e589aa-eb22-4623-bbe6-96585b4b3ff9} 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. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 47, line 69) (in query: select mapFromArrays([1, 2], [4, 'a']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002c4de745 7. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ca94bda 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ConstantNode* std::construct_at[abi:ne190107](DB::ConstantNode*, DB::Field const&) @ 0x000000002cbd0806 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::Field const&) @ 0x000000002cbd06bf 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x000000002cbd053a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba7fc8 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba8af5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 17. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 18. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:36.499463 [ 34261 ] {} 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. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002c4de745 7. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ca94bda 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ConstantNode* std::construct_at[abi:ne190107](DB::ConstantNode*, DB::Field const&) @ 0x000000002cbd0806 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::Field const&) @ 0x000000002cbd06bf 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x000000002cbd053a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba7fc8 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba8af5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 17. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 18. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:25:36.593335 [ 34261 ] {69976d28-5a7d-4706-920c-cf5d4b5dd85e} executeQuery: Code: 190. DB::Exception: Two arguments of function mapFromArrays must have equal sizes: In scope SELECT mapFromArrays(['aa', 'bb'], map('a', 4)). (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 48, line 70) (in query: select mapFromArrays(['aa', 'bb'], map('a', 4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd9219 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.605364 [ 34261 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments of function mapFromArrays must have equal sizes: In scope SELECT mapFromArrays(['aa', 'bb'], map('a', 4)). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd9219 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.665602 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:36.758931 [ 34261 ] {703a319a-3c2e-4805-bbb3-7dece52440c7} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays(CAST([1, NULL], 'Array(Nullable(UInt8))'), [3, 4]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40892) (comment: 01651_map_functions.sql) (query 49, line 71) (in query: select mapFromArrays([1,null]::Array(Nullable(UInt8)), [3,4]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd942d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.768813 [ 34261 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays(CAST([1, NULL], 'Array(Nullable(UInt8))'), [3, 4]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd942d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:36.904932 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:36.994900 [ 29256 ] {4623479e-b755-424b-9d0d-f8c2c8a1f27e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=28): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/data.bin (position: 7835674, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0d149ff8aa492ebc85f51752c0f57e0e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 119 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47292) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:37.003327 [ 29256 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=28): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/data.bin (position: 7835674, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0d149ff8aa492ebc85f51752c0f57e0e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 119 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:37.381251 [ 34260 ] {676b54d2-105b-4cb3-8e32-7e6906a5a387} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=33): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/data.bin (position: 625537, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 06bb4a247628dc8390222e15b04fecbd828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 9 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47256) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:37.398207 [ 34260 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=33): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/data.bin (position: 625537, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 06bb4a247628dc8390222e15b04fecbd828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 9 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:37.482211 [ 34340 ] {dfda5259-3937-4bde-9ebb-51b094ff16dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=30): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 164615, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 434986d1b70fa299a7a9e36ed31466cc828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 2 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47444) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:37.488633 [ 34340 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=30): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 164615, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 434986d1b70fa299a7a9e36ed31466cc828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 2 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:37.717107 [ 5105 ] {f17a8299-3765-43d4-9815-b59ee400f782} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47300) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:25:37.772228 [ 5105 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222579f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:38.108145 [ 5971 ] {752fa5fe-36b7-43e0-b2c4-21047221341f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=34): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/data.bin (position: 5168911, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: f1196d5b614ca40e3b5065dd406f7d67828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 78 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47262) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:38.127037 [ 5971 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=34): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/data.bin (position: 5168911, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: f1196d5b614ca40e3b5065dd406f7d67828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 78 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:38.220585 [ 5379 ] {44e08aae-30b9-43a6-8942-99cdcce08e4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=32): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 7868597, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 051d6da6eca6da59306c5d5f901ddc8c828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 119 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47340) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:38.242133 [ 5379 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=55, jobs=32): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 7868597, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 051d6da6eca6da59306c5d5f901ddc8c828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 119 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:38.307141 [ 34272 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:38.553363 [ 3449 ] {6ab6daed-b0ec-4894-bd39-fd804c29f950::all_13_18_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:38.555335 [ 3449 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6ab6daed-b0ec-4894-bd39-fd804c29f950::all_13_18_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:38.938798 [ 34275 ] {212923a9-52f6-4793-84e8-e7460aa13f47} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=15): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/data.bin (position: 1514458, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 03b1f84c0f4287b51624f5161d169fbc828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 23 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47506) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:38.968610 [ 34275 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=15): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/data.bin (position: 1514458, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 03b1f84c0f4287b51624f5161d169fbc828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 23 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:39.724849 [ 34277 ] {ac0cf6e0-c698-4992-a9bd-32ac580466eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=38): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/data.bin (position: 2436302, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5e0342e2842f48eaf349e791508839e0828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 37 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47564) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:39.727592 [ 7056 ] {73939765-8269-47a5-8929-7a5bfc85b779} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=20): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/data.bin (position: 7243060, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 76357c6f65c14d351371663f3e675cc0828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 110 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47466) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:39.739649 [ 34277 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=38): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/data.bin (position: 2436302, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5e0342e2842f48eaf349e791508839e0828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_9_9_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 37 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:39.761437 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=20): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/data.bin (position: 7243060, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 76357c6f65c14d351371663f3e675cc0828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 110 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:39.809822 [ 3766 ] {759f360d-8d47-48ff-a767-040c46ece40c} executeQuery: Code: 10. DB::Exception: Column `v2` not found in table test_t3um1915.mv_extra_columns_dst (1bd7c2e3-d158-4446-9052-79aeb9335496). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47572) (comment: 01019_materialized_view_select_extra_columns.sql) (query 9, line 31) (in query: SELECT * FROM mv_extra_columns_view;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:215: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x00000000307e20ff 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:349: 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) @ 0x00000000321965c7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3c62a 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: 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 @ 0x0000000030e1dc66 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: 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 @ 0x0000000030e1d95c 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311d5934 11. ./build_docker/./src/Storages/StorageMaterializedView.cpp:362: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000304dfa14 12. ./build_docker/./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) @ 0x000000002ddac77e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:39.828685 [ 3766 ] {} TCPHandler: Code: 10. DB::Exception: Column `v2` not found in table test_t3um1915.mv_extra_columns_dst (1bd7c2e3-d158-4446-9052-79aeb9335496). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:215: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x00000000307e20ff 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:349: 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) @ 0x00000000321965c7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3c62a 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: 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 @ 0x0000000030e1dc66 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: 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 @ 0x0000000030e1d95c 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311d5934 11. ./build_docker/./src/Storages/StorageMaterializedView.cpp:362: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000304dfa14 12. ./build_docker/./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) @ 0x000000002ddac77e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:25:39.987899 [ 5072 ] {4e7d0182-f956-4118-a66d-a715f16f0198} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=32): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 3917837, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3affe76046af670544b89ba1dd44bd6a828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 59 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47530) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:40.007196 [ 5072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=32): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 3917837, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3affe76046af670544b89ba1dd44bd6a828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 59 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:40.130532 [ 34268 ] {6eb031ca-7094-478a-95e7-82deaba293a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=23): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 2139995, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7e5aed8c3fad7d88072202c714295af5828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 32 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47554) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:40.156195 [ 34268 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=23): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 2139995, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7e5aed8c3fad7d88072202c714295af5828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 32 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:40.393436 [ 4529 ] {6493e820-dd31-432d-af06-8bbc3d536ceb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=38): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_5_5_0/data.bin (position: 2008303, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 09af22c1b93e774be498ace3590782ea828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_5_5_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 30 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47600) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:40.420460 [ 5476 ] {3a37f5ce-8cc9-42f2-9928-e78d15b359f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=925, jobs=909). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60520) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:40.422845 [ 4529 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=38): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_5_5_0/data.bin (position: 2008303, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 09af22c1b93e774be498ace3590782ea828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_5_5_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 30 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:40.442634 [ 5476 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=925, jobs=909). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:40.697796 [ 34277 ] {176c506c-1b4b-4ded-a7af-4958f903dd59} 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([], rowNumberInBlock())). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60536) (comment: 00811_garbage.sql) (query 3, line 4) (in query: SELECT ( SELECT toDecimal128([], rowNumberInBlock()) ) , lcm('', [[(CAST(('>A') AS String))]]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b0518d1 8. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b0515e7 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:25:40.706238 [ 34277 ] {} 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([], rowNumberInBlock())). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b0518d1 8. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b0515e7 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:25:40.941571 [ 34340 ] {0e08d10d-3865-4fe9-82ad-a3a6b8f92b2d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=24): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_2_2_0/data.bin (position: 2567994, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ea189a175be1a223eb6eed81eed9a166828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_2_2_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 39 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47516) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:41.067875 [ 34340 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=24): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_2_2_0/data.bin (position: 2567994, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ea189a175be1a223eb6eed81eed9a166828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_2_2_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 39 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:41.336863 [ 34277 ] {e2c07a48-e268-47c6-9edf-5aabe39c39d7} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60630) (comment: 03162_dynamic_type_nested.sql) (query 3, line 4) (in query: CREATE TABLE t (d Dynamic) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:41.368471 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:41.509588 [ 5382 ] {5dd05118-9952-41fa-8df3-db282bfe9100} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=26): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/data.bin (position: 1711996, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7aa586d2957aeba3ab8b1b9f71f3f762828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 26 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60488) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:41.544190 [ 5382 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=26): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/data.bin (position: 1711996, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7aa586d2957aeba3ab8b1b9f71f3f762828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_6_6_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 26 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:41.747234 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:41.953141 [ 29256 ] {de5b1d01-3421-4e66-b077-ce3c28a6b2c2} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_ti3pumj6.v (39094c15-35d5-4ea7-b9aa-73d4244d41c9), because some tables depend on it: test_ti3pumj6.dict. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60624) (comment: 03243_create_or_replace_view_dependency_check.sql) (query 7, line 16) (in query: drop view v;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:41.965505 [ 29256 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_ti3pumj6.v (39094c15-35d5-4ea7-b9aa-73d4244d41c9), because some tables depend on it: test_ti3pumj6.dict. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:41.979752 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:42.327436 [ 29256 ] {1fa55241-e8f2-4428-8d8e-b4b65344cc3a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60624) (comment: 03243_create_or_replace_view_dependency_check.sql) (query 8, line 17) (in query: create or replace view v (x UInt32, v String, y UInt32) as select x, v, 42 as y from test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:42.381784 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:25:42.845653 [ 3885 ] {5e82c13f-8c17-44db-88de-1277c442ace3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=17): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/data.bin (position: 3786145, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 832a646f787d23e8b6a10151993f9b0c828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 57 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60514) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:42.865088 [ 3885 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=17): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/data.bin (position: 3786145, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 832a646f787d23e8b6a10151993f9b0c828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_3_3_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 57 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:43.752012 [ 3028 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d604150 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d6048e1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:43.764830 [ 34260 ] {8ac7676f-f724-4fe8-80e1-8ed783fa7769} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=15): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 8922133, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: eefa8fb2b7fcb29c510406361b4d2d6982ad5e0000445e0000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 135 with max_rows_to_read = 22417): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60570) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:25:43.798021 [ 34260 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=15): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 8922133, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: eefa8fb2b7fcb29c510406361b4d2d6982ad5e0000445e0000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 135 with max_rows_to_read = 22417): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:43.888198 [ 7056 ] {e8335f5b-e699-4525-9120-d62e6073f869} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=11): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/data.bin (position: 2370456, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b61dd3483c2e6e900cfb2c3aa7d4aee5828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 36 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60534) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:43.902013 [ 7056 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=11): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/data.bin (position: 2370456, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b61dd3483c2e6e900cfb2c3aa7d4aee5828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_4_4_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 36 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:44.045406 [ 34261 ] {fe514a79-1e63-436c-823c-a26b691eb7a5} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60752) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 1, line 1) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.058846 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.133073 [ 34261 ] {79feacaf-29d9-47a7-99c9-aef05f03d422} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60752) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 2, line 2) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.144472 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.233605 [ 34261 ] {39f6de43-91ea-436e-8a6c-4561e6895ae2} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and Date32 of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60752) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 3, line 3) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.239244 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and Date32 of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.334946 [ 34261 ] {e8bd47be-f9f1-4d8a-b597-6673cb4a6cf3} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60752) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 4, line 4) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.351976 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.406491 [ 34261 ] {6bb886e9-59cd-4d6b-adac-9a1040c247f2} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime64(3) of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60752) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 5, line 5) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.419448 [ 34261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime64(3) of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78fb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20c091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:25:44.764144 [ 6126 ] {355858cf-4a49-4d7e-af95-3fa7739037be} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47176) (comment: 01115_join_with_dictionary.sql) (query 80, line 117) (in query: DROP DICTIONARY dict_flat;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:25:44.774845 [ 6126 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:25:44.800251 [ 3900 ] {165f1d54-9290-420f-8294-f67e25e2a80b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=18): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/data.bin (position: 6321216, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 998395a4c894440aad84bb39cf774af3828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 96 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60650) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:44.816336 [ 3900 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=18): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/data.bin (position: 6321216, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 998395a4c894440aad84bb39cf774af3828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_7_7_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 96 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:45.189243 [ 29256 ] {b56fd525-85b3-4fdd-9942-04961cc6dbdf} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43140) (comment: 01115_join_with_dictionary.sql) (in query: DROP DATABASE IF EXISTS test_lzxzicyb SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:25:45.192268 [ 29256 ] {b56fd525-85b3-4fdd-9942-04961cc6dbdf} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:45.789602 [ 5379 ] {823fe0a2-3b9f-4989-916e-773263573477} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=18): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_1_6_1/a.bin (position: 17836308, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0b26bb7a22c69c50eda57f4ac010045d820b01010000000100): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_1_6_1/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 539 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60596) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:25:45.881693 [ 5379 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=18): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_1_6_1/a.bin (position: 17836308, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0b26bb7a22c69c50eda57f4ac010045d820b01010000000100): (while reading column a): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_1_6_1/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 539 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:46.644986 [ 2824 ] {6dd626c2-9b2f-47c6-9e3e-66755304b6bf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=11): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 6485831, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5d4559c8a85e12994c661d143e6a5bad828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 98 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60708) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 2025.07.13 02:25:46.659981 [ 2824 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=11): While reading or decompressing /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/data.bin (position: 6485831, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5d4559c8a85e12994c661d143e6a5bad828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/b4c/b4cdbb16-34e7-4aab-8459-688fe60f3480/all_8_8_0/ in table test_7.t_index_hypothesis (b4cdbb16-34e7-4aab-8459-688fe60f3480) located on disk default of type local, from mark 98 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c604e43 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:46.808582 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:47.061696 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:49.004503 [ 3885 ] {a153f044-0d9f-42a3-81f6-190a4b050c59} 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.3.20372.altinityantalya (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.3.20372.altinityantalya (altinity build)) (from [::1]:60928) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c95db 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002852f576 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:49.010918 [ 3885 ] {} 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.3.20372.altinityantalya (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c95db 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002852f576 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c482 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:49.795873 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:49.797592 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:49.803500 [ 4529 ] {2f767055-a9b6-4dd2-8f59-cc755c9ba701} executeQuery: Code: 452. DB::Exception: Received from 127.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48844) (comment: 01940_custom_tld_sharding_key.sql) (query 1, line 3) (in query: select * from remote('127.{1,2}', view(select 'foo.com' key), cityHash64(key)) where key = cutToFirstSignificantSubdomainCustom('foo.com', 'public_suffix_list') settings optimize_skip_unused_shards=1, force_optimize_skip_unused_shards=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:49.835012 [ 4529 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:50.332507 [ 34275 ] {ef264b0f-2a22-4569-9a88-77bfb7437b76} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=868). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47718) (comment: 00223_shard_distributed_aggregation_memory_efficient.sql) (query 12, line 17) (in query: SELECT count() AS `c` FROM `test_eus85m4o`.`numbers_10_00223` AS `__table1` WHERE `__table1`.`number` < _CAST(5, 'UInt8') GROUP BY `__table1`.`number`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:50.341233 [ 34275 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=868). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:50.377101 [ 5105 ] {88ca12ba-718c-4d17-89a9-b3e9306a2a64} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=868). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60730) (comment: 00223_shard_distributed_aggregation_memory_efficient.sql) (query 12, line 17) (in query: SELECT sum(c = 1) IN (0, 5), sum(c = 2) IN (5, 10) FROM (SELECT number, count() AS c FROM remote('127.0.0.{2,3}', currentDatabase(), numbers_10_00223) WHERE number < (randConstant() % 2 ? 5 : 10) GROUP BY number);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:25:50.410897 [ 5105 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=868). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:25:50.487973 [ 4529 ] {c61519e7-d79b-447b-a516-10e53728fc96} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:58290). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:50.499864 [ 4529 ] {c61519e7-d79b-447b-a516-10e53728fc96} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:58290). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:58290) (comment: 00223_shard_distributed_aggregation_memory_efficient.sql) (query 12, line 17) (in query: SELECT count() AS `c` FROM `test_eus85m4o`.`numbers_10_00223` AS `__table1` WHERE `__table1`.`number` < _CAST(5, 'UInt8') GROUP BY `__table1`.`number`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:25:50.504953 [ 4529 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:58290). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:25:51.565513 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:25:51.583171 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:25:51.889966 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:52.156686 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:52.551838 [ 34268 ] {0bb2d72b-d05a-4dec-99ce-2e66f6f5c9d7} 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.3.20372.altinityantalya (altinity build)) (from [::1]:48902) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002c696650 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e2631cb 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0d0d28 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b50d7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:25:52.560684 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3282b 5. ./src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002c696650 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e2631cb 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0d0d28 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b50d7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:25:52.716211 [ 34268 ] {cd03246f-312f-40dc-a590-80a8d755da1b} 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.3.20372.altinityantalya (altinity build)) (from [::1]:48902) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5243c9 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 16. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 18. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 19. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:25:52.724883 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5243c9 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 16. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 18. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 19. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:25:55.830847 [ 34275 ] {820cb0a0-ca37-470c-ab70-73ea565d4c64} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49000) (comment: 02346_fulltext_index_search.sql) (query 6, line 13) (in query: CREATE TABLE tab (`k` UInt64, `s` String, INDEX af s TYPE full_text(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 2, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 75, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 173850346, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 5203491, merge_max_block_size = 10813, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 725000090, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 45823, primary_key_compress_block_size = 8757, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:55.857636 [ 34275 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.032180 [ 2824 ] {73460bc5-5feb-42f9-8a3a-dee36a871339} executeQuery: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 17, line 39) (in query: ALTER TABLE table_with_version MODIFY COLUMN version String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.046083 [ 2824 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.119612 [ 2824 ] {7d63fa24-b896-494a-b6d7-5e4ad6d0198a} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 18, line 40) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Int64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.123124 [ 2824 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.431449 [ 2824 ] {a61475a0-4d3c-4aec-a3d7-7968b7d2c48d} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 19, line 41) (in query: ALTER TABLE table_with_version MODIFY COLUMN version UInt16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3493: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7426 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.438763 [ 2824 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3493: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7426 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.574448 [ 2824 ] {388505bd-7c83-42b9-8cde-ea69a1dcb50d} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 20, line 42) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Float64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.592617 [ 2824 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.708571 [ 2824 ] {a85784a2-39f2-4a3c-b9e7-84e4e0b56ba2} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 21, line 43) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.724693 [ 2824 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.780091 [ 5379 ] {c49d293e-35dc-4641-a183-f0e912445c95} PushingToViews: Failed to push block to view test_13.view (6b8a7bfb-a964-43df-9e81-389b4a564333), Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp'] 2025.07.13 02:25:56.800517 [ 2824 ] {52e3b040-458d-4168-b4ca-27bf77674e7d} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 22, line 44) (in query: ALTER TABLE table_with_version MODIFY COLUMN version DateTime;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:56.806103 [ 2824 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:25:57.022576 [ 5379 ] {c49d293e-35dc-4641-a183-f0e912445c95} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49042) (comment: 01442_date_time_with_params.sql) (query 3, line 5) (in query: INSERT INTO test VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:25:57.027570 [ 5379 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:25:57.043903 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:57.256529 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:57.883599 [ 29256 ] {9b63b298-2638-4031-9767-4cfaa75cd98c} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode('Hold my beer...', 'Second arg'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49092) (comment: 02337_base58.sql) (query 2, line 5) (in query: SELECT base58Encode('Hold my beer...', 'Second arg');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:25:57.887199 [ 29256 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode('Hold my beer...', 'Second arg'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:25:58.107521 [ 29256 ] {e1316858-754d-46b4-ae48-50e806589a19} executeQuery: Code: 36. DB::Exception: Invalid Base58 value, cannot be decoded: In scope SELECT base58Decode('Hold my beer...'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49092) (comment: 02337_base58.sql) (query 3, line 6) (in query: SELECT base58Decode('Hold my beer...');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionBase58Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4380e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:58.124789 [ 29256 ] {} TCPHandler: Code: 36. DB::Exception: Invalid Base58 value, cannot be decoded: In scope SELECT base58Decode('Hold my beer...'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionBase58Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4380e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:58.330843 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:58.688545 [ 3900 ] {4881b6f7-5c86-402a-8483-55e8d76b9d4f} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49120) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 1, line 1) (in query: SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:25:58.694622 [ 3900 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:25:58.874365 [ 3900 ] {383d6975-6576-42bd-b690-4bd543c773eb} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49120) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 2, line 2) (in query: SELECT '-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:25:58.880966 [ 3900 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:25:59.875396 [ 3900 ] {78e9f740-7e29-4dd4-a092-ec0795d96c97} executeQuery: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-9' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49120) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 8, line 8) (in query: SELECT '1E-9' AS x, toDecimal32(x, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:59.882442 [ 3900 ] {} TCPHandler: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-9' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:59.950938 [ 3900 ] {08e836d3-c32f-45d3-9723-e0e574b0d20f} executeQuery: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-10' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49120) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 9, line 9) (in query: SELECT '1E-10' AS x, toDecimal32(x, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:25:59.956129 [ 3900 ] {} TCPHandler: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-10' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:26:02.201891 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:02.298143 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:02.932468 [ 5971 ] {981d9c7e-3b89-4fb5-959b-e477bd2e3d90} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.57 MiB (attempt to allocate chunk of 2.15 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_5.mv_01278_3 (c8b57a2a-6973-46b8-9c16-34783dc65de1). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34370) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:228: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000030225b0b 11. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fd2a101 12. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fcb3ca5 13. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000030230784 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:272: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dccd21 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f113c5 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc55a1 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4361 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 30. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 2025.07.13 02:26:02.965720 [ 5971 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.57 MiB (attempt to allocate chunk of 2.15 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_5.mv_01278_3 (c8b57a2a-6973-46b8-9c16-34783dc65de1). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc4b14 10. ./src/Common/PODArray.h:228: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000030225b0b 11. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fd2a101 12. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fcb3ca5 13. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000030230784 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:272: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dccd21 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f113c5 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc55a1 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4361 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 30. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:26:03.013607 [ 4529 ] {44f31ccc-d3e2-45e4-bc8b-7ef964fc4427} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48956) (comment: 01015_empty_in_inner_right_join.gen.sql) (query 37, line 52) (in query: SELECT 'IN empty set equals 0', count() FROM numbers(10) WHERE (number IN (SELECT toUInt64(1) WHERE 0)) = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:03.034613 [ 4529 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:03.294716 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:03.351705 [ 6903 ] {be6080b4-1642-4d62-81d4-b1e9e5b0eed9} ExternalDictionariesLoader: Could not update external dictionary 'cdc20bcf-fbab-4b72-a968-cd81da26c038', leaving the previous version: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000028a90115 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a9207f 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:03.357349 [ 33000 ] {be6080b4-1642-4d62-81d4-b1e9e5b0eed9} executeQuery: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34362) (comment: 02504_regexp_dictionary_table_source.sql) (query 22, line 59) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000028a90115 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a9207f 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:26:03.360685 [ 33000 ] {} TCPHandler: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000028a90115 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a9207f 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:26:04.222507 [ 6875 ] {ecdd1d60-72d6-479f-906e-7433e9e4d5a1} ExternalDictionariesLoader: Could not update external dictionary 'cdc20bcf-fbab-4b72-a968-cd81da26c038', leaving the previous version: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x0000000028a918d5 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a920b1 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:04.228924 [ 33000 ] {ecdd1d60-72d6-479f-906e-7433e9e4d5a1} executeQuery: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34362) (comment: 02504_regexp_dictionary_table_source.sql) (query 25, line 64) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x0000000028a918d5 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a920b1 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:26:04.232034 [ 33000 ] {} TCPHandler: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019f00e4f 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x0000000028a918d5 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a920b1 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:26:05.360223 [ 36900 ] {31f9b716-f5de-46e2-8c2a-942672479de2} ExternalDictionariesLoader: Could not update external dictionary 'cdc20bcf-fbab-4b72-a968-cd81da26c038', leaving the previous version: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x0000000028a91a31 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a920b1 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:05.369113 [ 33000 ] {31f9b716-f5de-46e2-8c2a-942672479de2} executeQuery: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34362) (comment: 02504_regexp_dictionary_table_source.sql) (query 30, line 71) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x0000000028a91a31 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a920b1 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:26:05.376629 [ 33000 ] {} TCPHandler: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x0000000028a91a31 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a920b1 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:26:06.057011 [ 5476 ] {a44fd09f-62f8-46a1-afe6-c51dea9c23f2} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 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 toInt8(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 10, line 14) (in query: SELECT toInt8(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:06.066975 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 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 toInt8(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:06.746156 [ 5476 ] {95c1fce7-1d60-499e-a2d6-da62572701e1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope SELECT toInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 13, line 17) (in query: SELECT toInt8(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:06.753240 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope SELECT toInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:06.945869 [ 5476 ] {3c90217a-c2db-4f01-ba11-4d6df9e0943a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 14, line 18) (in query: SELECT toInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:06.969212 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:07.161770 [ 36813 ] {7e820f94-984c-4ba1-9168-561552851c2b} ExternalDictionariesLoader: Could not update external dictionary 'cdc20bcf-fbab-4b72-a968-cd81da26c038', leaving the previous version: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a93493 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:07.255725 [ 33000 ] {7e820f94-984c-4ba1-9168-561552851c2b} executeQuery: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34362) (comment: 02504_regexp_dictionary_table_source.sql) (query 38, line 82) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a93493 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:07.263810 [ 33000 ] {} TCPHandler: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x0000000028a93493 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000028a946b7 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000028a9d198 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acbc29d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acbb587 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbecc23 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dc04df1 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbff463 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc19755 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc194ff 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000002dbf9de3 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x000000002dbf7383 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x000000002dbee4fa 11. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f7fbe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:26:07.294931 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:07.438689 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:09.204395 [ 34272 ] {739ceaa8-dd33-481b-9146-6e781ea4be3f} executeQuery: Code: 57. DB::Exception: Table test_7.t_json_empty_parts already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33680) (comment: 02421_new_type_json_empty_parts.sh) (query 1, line 1) (in query: CREATE TABLE t_json_empty_parts (`id` UInt64, `data` JSON) ENGINE = MergeTree ORDER BY id SETTINGS old_parts_lifetime = 5, index_granularity = 48112, min_bytes_for_wide_part = 450650381, ratio_of_defaults_for_sparse_serialization = 0.8313820958137512, 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 = 266422218, compact_parts_max_granules_to_buffer = 102, compact_parts_merge_max_bytes_to_prefetch_part = 33222863, merge_max_block_size = 17239, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 40, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 13745437, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 12960, primary_key_compress_block_size = 64903, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:09.271591 [ 34272 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t_json_empty_parts already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:09.664415 [ 3816 ] {305e9611-d35e-4ba0-87d7-c876ba7b1b7d} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47548) (comment: 02534_keyed_siphash.sql) (query 193, line 266) (in query: select sipHash64Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4b57 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180127c1 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180124d8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:09.681919 [ 3816 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4b57 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180127c1 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180124d8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:09.788871 [ 5476 ] {1def0183-304c-4aca-a45d-4ff0dec8f640} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int16 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 toInt16(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 25, line 30) (in query: SELECT toInt16(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:09.821210 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int16 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 toInt16(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:09.863879 [ 3816 ] {55b74dc2-c264-42ea-b6ff-968e1ceadc5e} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47548) (comment: 02534_keyed_siphash.sql) (query 194, line 267) (in query: select sipHash128Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4b57 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5655 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5358 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:09.876754 [ 3816 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4b57 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5655 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5358 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:10.104851 [ 5105 ] {c5405e50-382c-43ef-b8e9-40738e978973} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33748) (comment: 01825_type_json_3.gen.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:10.120008 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:10.171609 [ 3816 ] {0ec82dce-108c-4348-bd9d-1c0bffff8927} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47548) (comment: 02534_keyed_siphash.sql) (query 195, line 268) (in query: select sipHash64Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4a2e 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180127c1 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180124d8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:10.177596 [ 3816 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4a2e 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180127c1 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180124d8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:10.423561 [ 3816 ] {2efd12e1-729a-47fe-826f-40505a516c33} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47548) (comment: 02534_keyed_siphash.sql) (query 196, line 269) (in query: select sipHash128Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4a2e 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5655 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5358 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:10.439040 [ 3816 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4a2e 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5655 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b5358 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:26:10.443492 [ 5476 ] {757c3912-1da8-413f-bb3e-96ca48e0755c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope SELECT toInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 28, line 33) (in query: SELECT toInt16(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:10.477644 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope SELECT toInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:10.603139 [ 5476 ] {3b3f38db-98e2-4191-a6f9-610c26a396f7} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 29, line 34) (in query: SELECT toInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:10.612236 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:10.860076 [ 3885 ] {320551c8-36a9-4919-ac76-7b2fa39b230f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33728) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:10.882063 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:11.092740 [ 10341 ] {200a356f-c812-4e00-ae03-e4c1581280dc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36910) (comment: 02246_flatten_tuple.sql) (in query: DROP DATABASE IF EXISTS test_rtyifch4 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:26:11.094533 [ 10341 ] {200a356f-c812-4e00-ae03-e4c1581280dc} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:12.415081 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:12.503524 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:12.757637 [ 34277 ] {a64afa39-b511-4501-8299-27e0dfbf9727} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Variant(String, UInt64), UInt8) of function equals: In scope SELECT * FROM test WHERE v = 42. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33798) (comment: 02990_variant_where_cond.sql) (query 5, line 7) (in query: select * from test where v = 42;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:12.769872 [ 34277 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Variant(String, UInt64), UInt8) of function equals: In scope SELECT * FROM test WHERE v = 42. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:12.828093 [ 5476 ] {a06e0b3d-cfbe-46f9-9ec7-53103fe10e3f} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int32 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 toInt32(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 40, line 46) (in query: SELECT toInt32(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:12.849293 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int32 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 toInt32(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.474361 [ 5476 ] {1d9a9452-8b4a-4367-9b4b-4c539ed07a68} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope SELECT toInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 43, line 49) (in query: SELECT toInt32(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.501430 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope SELECT toInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.663394 [ 34277 ] {759d0c1c-d71a-4c40-ba18-06e89e4c0b80} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-1e-7). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33828) (comment: 03213_rand_dos.sql) (query 1, line 1) (in query: SELECT randChiSquared(-0.0000001);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206075d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.674067 [ 34277 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-1e-7). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206075d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.678518 [ 5476 ] {efe0028a-ce27-4df9-863d-598469cff7d4} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 44, line 50) (in query: SELECT toInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:13.696237 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:13.748329 [ 34277 ] {8abc414b-088e-406f-84c8-09c3fa7cc833} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-0.). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33828) (comment: 03213_rand_dos.sql) (query 2, line 2) (in query: SELECT randChiSquared(-0.0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206075d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.752177 [ 34277 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206075d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.837320 [ 34277 ] {3c77e086-9d84-45c2-a6dc-3941deb281f8} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randStudentT should be greater than zero: In scope SELECT randStudentT(-0.). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33828) (comment: 03213_rand_dos.sql) (query 3, line 3) (in query: SELECT randStudentT(-0.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020608c2d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.843479 [ 34277 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randStudentT should be greater than zero: In scope SELECT randStudentT(-0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020608c2d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.924244 [ 34277 ] {ff0ee273-1f30-407b-92ca-b6793085b016} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(-0., 1). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33828) (comment: 03213_rand_dos.sql) (query 4, line 4) (in query: SELECT randFisherF(-0., 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020609e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:13.945672 [ 34277 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(-0., 1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020609e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:14.088578 [ 34277 ] {b579ff31-73a7-40e5-b036-1f471378278e} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(1, -0.). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33828) (comment: 03213_rand_dos.sql) (query 5, line 5) (in query: SELECT randFisherF(1, -0.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020609e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:14.093403 [ 34277 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(1, -0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdfb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020609e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:15.903477 [ 34277 ] {87cbd924-98ec-43d0-80d1-37e0046af42a} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33848) (comment: 02792_alter_table_modify_comment.sql) (query 12, line 20) (in query: CREATE TABLE t (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 25601, min_bytes_for_wide_part = 582363143, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 95, min_bytes_for_full_part_storage = 443578972, compact_parts_max_bytes_to_buffer = 475499356, compact_parts_max_granules_to_buffer = 37, compact_parts_merge_max_bytes_to_prefetch_part = 29295047, merge_max_block_size = 20610, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 6703596079, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 31240483, 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 = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 75232, primary_key_compress_block_size = 97260, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true COMMENT 'Hello'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:15.921130 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:16.092279 [ 5476 ] {df609701-3ff1-43b5-ba91-1546bb580f3d} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int64 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 toInt64(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 55, line 62) (in query: SELECT toInt64(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.108681 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int64 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 toInt64(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.378555 [ 5476 ] {bd3cbc34-bdb2-43a7-aade-d3a6ae2bb6e2} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float32, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 56, line 63) (in query: SELECT toInt64(0) AS x, toFloat32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.381842 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float32, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.448559 [ 5476 ] {721d94a0-7a92-4840-b3dc-119c7168c409} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float64, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 57, line 64) (in query: SELECT toInt64(0) AS x, toFloat64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.461092 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float64, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.653602 [ 5476 ] {118d6836-bab4-4f12-bb21-b4452b3db8f3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope SELECT toInt64(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 58, line 65) (in query: SELECT toInt64(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.683162 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope SELECT toInt64(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:16.821545 [ 5476 ] {5d291114-6b6b-4fb3-82f4-23b33716ccfa} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 59, line 66) (in query: SELECT toInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:16.843364 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:17.566456 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:17.586016 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:17.879620 [ 3458 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {875c7d93-8284-4a3b-8879-b998f9b38c45::all_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:18.344673 [ 33006 ] {955165a5-0d02-4ff2-94dc-6c0c35f16d59} executeQuery: Code: 128. DB::Exception: Array size -231 cannot be negative: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(-231.37104, -138). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33950) (comment: 00842_array_with_constant_overflow.sql) (query 1, line 1) (in query: SELECT arrayWithConstant(-231.37104, -138);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000001f40bfaf 5. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002327b0c8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:26:18.349662 [ 33006 ] {} TCPHandler: Code: 128. DB::Exception: Array size -231 cannot be negative: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(-231.37104, -138). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000001f40bfaf 5. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002327b0c8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:26:18.367940 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:18.911562 [ 34273 ] {e3c7ac10-1a57-4bdd-bf4d-d2fda9f2f431} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.80 MiB (attempt to allocate chunk of 1.04 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_5.mv_01278_7 (1a02ea9a-9733-48cd-88ab-f059aad16629). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34402) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 10. ./src/Common/PODArray.h:228: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000030225bb1 11. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fd2a101 12. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fcb3ca5 13. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000030230784 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:272: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dccd21 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f113c5 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc55a1 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4361 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 30. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 2025.07.13 02:26:18.964197 [ 34273 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.80 MiB (attempt to allocate chunk of 1.04 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_5.mv_01278_7 (1a02ea9a-9733-48cd-88ab-f059aad16629). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc93d4 10. ./src/Common/PODArray.h:228: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000030225bb1 11. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fd2a101 12. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000002fcb3ca5 13. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000030230784 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:272: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dccd21 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f113c5 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc55a1 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc4361 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 30. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:26:19.218182 [ 4529 ] {fe6818ca-2b14-4169-a7fb-d42bc32417a6} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33964) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003086411a 6. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x000000002e34717b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:26:19.223739 [ 4529 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003086411a 6. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x000000002e34717b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:26:19.294202 [ 4529 ] {7459accb-1562-4157-b389-ccb64ffa662f} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33964) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003086411a 6. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x000000002e34717b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:26:19.300504 [ 4529 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003086411a 6. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x000000002e34717b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:26:19.891683 [ 5476 ] {8309e60e-80a9-4ff2-a536-7cedebb391b4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope SELECT toUInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 73, line 81) (in query: SELECT toUInt8(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:19.896941 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope SELECT toUInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:20.056733 [ 5476 ] {5eda874d-86a9-4b16-80bd-b0ce33d2e1c4} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 74, line 82) (in query: SELECT toUInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:20.067687 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:21.983713 [ 3816 ] {cb8b72b3-9bba-440e-be58-ea37aa5e2088} executeQuery: Code: 57. DB::Exception: Table test_fkx25jd9.sipHashKeyed_keys already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02534_keyed_siphash.sql) (in query: /* ddl_entry=query-0000000011 */ CREATE TABLE test_fkx25jd9.sipHashKeyed_keys UUID 'a7e85abb-145c-476d-a7aa-147e9debf14b' (`key0` UInt64, `key1` UInt64) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:26:22.059377 [ 3816 ] {cb8b72b3-9bba-440e-be58-ea37aa5e2088} executeQuery: Code: 57. DB::Exception: Table test_fkx25jd9.sipHashKeyed_keys already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47548) (comment: 02534_keyed_siphash.sql) (query 247, line 328) (in query: CREATE TABLE sipHashKeyed_keys (key0 UInt64, key1 UInt64) ENGINE=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:26:22.066282 [ 3816 ] {} TCPHandler: Code: 57. DB::Exception: Table test_fkx25jd9.sipHashKeyed_keys already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:26:22.865234 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:22.874295 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:23.538122 [ 5476 ] {ed65618d-9169-46b7-afb9-f524fb9a605f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope SELECT toUInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 88, line 97) (in query: SELECT toUInt16(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:23.552471 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope SELECT toUInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:23.670671 [ 5476 ] {b90918a3-03bd-465b-a4c0-5aa4b3e437f5} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 89, line 98) (in query: SELECT toUInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:23.774629 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:24.135710 [ 4938 ] {78d9f734-ffd6-4fe3-b31f-0e27a762842e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=865). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49106) (comment: 00871_t64_codec_signed.sql) (query 88, line 109) (in query: INSERT INTO t64 SELECT (intExp2(56) - 64 + number) AS x, x, x, x, x, x, x, x FROM numbers(2049);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:26:24.160545 [ 4938 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=865). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:26:26.922847 [ 34261 ] {a2671e79-8a32-4b6d-8054-d135a61b3754} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 15_UInt8) :: 0) -> throwIf(equals(__table1.number, 15_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44416) (comment: 03174_json_compact_with_progress.sh) (in query: SELECT throwIf(number = 15), 1::Int64 as a, '"' from numbers(100) format JSONCompactEachRowWithProgress settings output_format_json_quote_64bit_integers=1, max_block_size=10), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 21. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 22. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 23. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:26.933541 [ 34261 ] {a2671e79-8a32-4b6d-8054-d135a61b3754} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 15_UInt8) :: 0) -> throwIf(equals(__table1.number, 15_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 21. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 22. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 23. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:26.951711 [ 5476 ] {07041dd7-b069-4938-be4a-6c3eec75f5a7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope SELECT toUInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 103, line 113) (in query: SELECT toUInt32(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:26.964314 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope SELECT toUInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:27.164255 [ 5476 ] {61f40fc3-4eeb-43a3-a5cf-a6bd161d0aa1} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 104, line 114) (in query: SELECT toUInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:27.191466 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:27.953213 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:27.989844 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:28.073390 [ 5476 ] {b6f050ab-daff-46ef-860f-3635eb016670} 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 toUInt64(0) AS x, toInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 108, line 119) (in query: SELECT toUInt64(0) AS x, toInt8(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.097648 [ 5476 ] {} 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 toUInt64(0) AS x, toInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.164110 [ 5476 ] {5119f3f6-69cb-4623-953e-2bdc56c69a95} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int16, 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 toUInt64(0) AS x, toInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 109, line 120) (in query: SELECT toUInt64(0) AS x, toInt16(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.167654 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int16, 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 toUInt64(0) AS x, toInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.298170 [ 5476 ] {214d1231-a361-46d7-93ff-e7ea41aeab6a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int32, 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 toUInt64(0) AS x, toInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 110, line 121) (in query: SELECT toUInt64(0) AS x, toInt32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.345466 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int32, 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 toUInt64(0) AS x, toInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.499286 [ 5476 ] {64bb8faa-5c0f-4fdf-b1c1-b51ba43d882f} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toUInt64(0) AS x, toInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 111, line 122) (in query: SELECT toUInt64(0) AS x, toInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.507980 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toUInt64(0) AS x, toInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:28.814107 [ 2824 ] {cfc9125b-228f-4ff8-96e4-5ecff33f496f} executeQuery: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53828) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c44bcfd 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846b5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846b3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028465948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846540d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846508b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], 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&) @ 0x0000000028464e6c 12. ./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 @ 0x0000000028464d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 15. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 16. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:26:28.818595 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c44bcfd 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846b5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846b3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028465948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846540d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846508b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], 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&) @ 0x0000000028464e6c 12. ./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 @ 0x0000000028464d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8d87 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 15. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3a8517 16. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:26:29.308434 [ 5476 ] {af0b13a1-0ea7-4f3f-9fa7-deb9b0d07f4f} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float32, UInt64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toUInt64(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 116, line 127) (in query: SELECT toUInt64(0) AS x, toFloat32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:29.311502 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float32, UInt64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toUInt64(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:29.485494 [ 5476 ] {b3747f5b-d544-44e5-adfe-c64fb144d9fb} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float64, UInt64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toUInt64(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 117, line 128) (in query: SELECT toUInt64(0) AS x, toFloat64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:29.521601 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float64, UInt64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toUInt64(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:29.660757 [ 5476 ] {9ba7969f-74d6-40cf-9b29-62a6875ecdab} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope SELECT toUInt64(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 118, line 129) (in query: SELECT toUInt64(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:29.677427 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope SELECT toUInt64(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:29.772749 [ 5476 ] {760760f7-f7cd-4ff6-bcd7-3ca60405daf5} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 119, line 130) (in query: SELECT toUInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:29.802994 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:30.684241 [ 5476 ] {77c55b7a-e088-4d20-b9bb-00e28dfd0cdb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope SELECT toDate(0) AS x, toInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 123, line 135) (in query: SELECT toDate(0) AS x, toInt8(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:30.708471 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope SELECT toDate(0) AS x, toInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:30.797869 [ 5476 ] {a8f48d53-31c1-4b63-ba66-847c14cb8599} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope SELECT toDate(0) AS x, toInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 124, line 136) (in query: SELECT toDate(0) AS x, toInt16(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:30.801581 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope SELECT toDate(0) AS x, toInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:30.973523 [ 5476 ] {71c30ee5-6146-4441-9e2e-2bd0e4fbd666} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope SELECT toDate(0) AS x, toInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 125, line 137) (in query: SELECT toDate(0) AS x, toInt32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.000643 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope SELECT toDate(0) AS x, toInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.188824 [ 5476 ] {3417155c-ae82-4900-8639-869bfa33ab8a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope SELECT toDate(0) AS x, toInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 126, line 138) (in query: SELECT toDate(0) AS x, toInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.208462 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope SELECT toDate(0) AS x, toInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.452973 [ 5476 ] {6a58b2fe-f841-4740-9d72-24cecee0b7b5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope SELECT toDate(0) AS x, toUInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 127, line 139) (in query: SELECT toDate(0) AS x, toUInt8(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.461771 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope SELECT toDate(0) AS x, toUInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.621980 [ 5476 ] {953f045d-7e80-424a-baa4-d8d8ba02af1b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope SELECT toDate(0) AS x, toUInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 128, line 140) (in query: SELECT toDate(0) AS x, toUInt16(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.650784 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope SELECT toDate(0) AS x, toUInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.758410 [ 5476 ] {70d28a73-e85e-4aa9-af5c-42ab05bd8b8d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope SELECT toDate(0) AS x, toUInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 129, line 141) (in query: SELECT toDate(0) AS x, toUInt32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.763249 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope SELECT toDate(0) AS x, toUInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.960811 [ 5476 ] {f1eacdc0-8235-41fc-bdba-46d4ca05b8b9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope SELECT toDate(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 130, line 142) (in query: SELECT toDate(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:31.982306 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope SELECT toDate(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:32.106317 [ 5476 ] {f9cd6d2d-3eb5-42d1-861a-4453b3ae94ec} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Float32) of function greater: In scope SELECT toDate(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 131, line 143) (in query: SELECT toDate(0) AS x, toFloat32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:32.159764 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Float32) of function greater: In scope SELECT toDate(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:32.264324 [ 5476 ] {a9072e10-40c2-4c7c-a453-2a63de1a38b8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Float64) of function greater: In scope SELECT toDate(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 132, line 144) (in query: SELECT toDate(0) AS x, toFloat64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:32.290227 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Float64) of function greater: In scope SELECT toDate(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.010703 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:33.049761 [ 5476 ] {f3755c5f-3e0e-44d6-9b67-e3d0e22a3821} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate(0) AS x, toDecimal32(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 135, line 147) (in query: SELECT toDate(0) AS x, toDecimal32(1, 0) AS y, ((x = 0) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.050053 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:33.062337 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate(0) AS x, toDecimal32(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.215456 [ 5476 ] {873a3fc4-8bf4-4b9e-bd13-dc8b19e55883} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate(0) AS x, toDecimal64(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 136, line 148) (in query: SELECT toDate(0) AS x, toDecimal64(1, 0) AS y, ((x = 0) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.239700 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate(0) AS x, toDecimal64(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.309058 [ 5476 ] {b568e6dc-0771-4c4c-9e1c-9d88332a282e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate(0) AS x, toDecimal128(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 137, line 149) (in query: SELECT toDate(0) AS x, toDecimal128(1, 0) AS y, ((x = 0) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.313112 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate(0) AS x, toDecimal128(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e6dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:33.372635 [ 5476 ] {f5fb0546-75e4-488a-8c2e-3528546b10ad} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int8 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 138, line 151) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt8(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.377569 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int8 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.509975 [ 5476 ] {c3167f8a-83d3-4721-9efe-4d998d7b6966} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int16 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 139, line 152) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt16(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.536942 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int16 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.771046 [ 5476 ] {daae3248-5a1d-40aa-a793-5920a913132b} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int32 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 140, line 153) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.794554 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int32 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.879231 [ 5476 ] {96a9bb1d-a4ed-405c-a5f1-20a24034c7fd} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int64 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 141, line 154) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.882328 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Int64 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.925724 [ 5476 ] {f2ab87d4-41e4-47c7-90fd-bce18ded6284} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt8 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 142, line 155) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt8(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.930465 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt8 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt8(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.983195 [ 5476 ] {eb5c4a18-38fe-4097-9685-737bc591e30a} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt16 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 143, line 156) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt16(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:33.988803 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt16 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt16(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.092488 [ 5476 ] {bbb7be51-962f-4abc-a3cb-5113e9ec9b12} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt32 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 144, line 157) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.097842 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt32 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.152779 [ 5476 ] {c10403d3-1194-4d40-9cb7-1d27acf1f688} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt64 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 145, line 158) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.159505 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), UInt64 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.258549 [ 5476 ] {cf8632bd-882b-4bab-b0ac-4d466bcb6927} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Float32 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 146, line 159) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toFloat32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.261927 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Float32 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.370525 [ 5476 ] {e2bc19d0-91c7-4a97-beef-dd9129b618f2} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Float64 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 147, line 160) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toFloat64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.472640 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Float64 because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.908291 [ 5476 ] {fb6944ec-46b7-4e89-97b0-703f44007f36} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Decimal(9, 0) because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal32(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 150, line 163) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal32(1, 0) AS y, ((x = 0) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:34.912693 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Decimal(9, 0) because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal32(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:35.004783 [ 5476 ] {9a01935c-4625-43b1-a1b1-63fe6db10662} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Decimal(18, 0) because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal64(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 151, line 164) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal64(1, 0) AS y, ((x = 0) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:35.012960 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Decimal(18, 0) because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal64(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:35.200139 [ 5476 ] {589d06d8-b16f-47b2-bb51-36a3c7d6fb60} executeQuery: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Decimal(38, 0) because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal128(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 152, line 165) (in query: SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal128(1, 0) AS y, ((x = 0) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:35.227094 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types DateTime('Asia/Istanbul'), Decimal(38, 0) because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toDateTime(0, 'Asia/Istanbul') AS x, toDecimal128(1, 0) AS y, if(x = 0, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:36.674738 [ 32979 ] {003c6143-0f4d-4455-b237-43ebc7fc1a63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41676) (comment: 01395_limit_more_cases.sh) (query 9, line 89) (in query: SELECT 0, 8, count() AS c, min(number) AS first, max(number) AS last, throwIf(first != (0 < 13 AND 8 > 0 ? 0 : 0)), throwIf(last != (0 < 13 AND 8 > 0 ? least(13 - 1, 0 + 8 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(13) LIMIT 0, 8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:36.692660 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:37.961398 [ 5476 ] {fe711801-18d5-4c58-ae0a-d022702eae28} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 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 materialize(toInt8(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 161, line 176) (in query: SELECT materialize(toInt8(0)) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:37.969707 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 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 materialize(toInt8(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:38.073612 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:38.112324 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:38.571802 [ 3900 ] {d5996b45-65cf-4503-900f-73225203a857} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:38.578153 [ 3900 ] {d5996b45-65cf-4503-900f-73225203a857} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41702) (comment: 01956_skip_unavailable_shards_excessive_attempts.sh) (query 1, line 1) (in query: select * from remote('255.255.255.255', system.one) settings use_hedged_requests=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000308540a5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028492e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284924c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:38.591126 [ 3900 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003085630e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000308540a5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028492e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284924c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:38.616549 [ 5476 ] {2d64fe6f-8c8c-4cf6-8008-8758988ded5a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope SELECT materialize(toInt8(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 164, line 179) (in query: SELECT materialize(toInt8(0)) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:38.648504 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope SELECT materialize(toInt8(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:38.869104 [ 5476 ] {e680c402-399e-4e90-92e9-0c37ec3cd8a8} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt8(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 165, line 180) (in query: SELECT materialize(toInt8(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:38.890213 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt8(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:39.410472 [ 6915 ] {0effa475-8a9b-4f67-85ac-6758c6eeb5f7} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:39.620398 [ 34259 ] {5b3fce02-76c9-45e4-9df8-b0d737fc721f} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60275.688361 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43692) (comment: 02177_issue_31009.sql) (query 10, line 18) (in query: SELECT key, count(1) AS cnt FROM ( SELECT data.key FROM ( SELECT key FROM left AS s ) AS data LEFT JOIN ( SELECT key FROM right GROUP BY key ) AS promo ON promo.key = data.key ) GROUP BY key HAVING count(1) > 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:39.656129 [ 34259 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60275.688361 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:39.941006 [ 33006 ] {09cf9abc-444c-41e0-8e7b-5cf9b0caecfb} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:40.163030 [ 36824 ] {09cf9abc-444c-41e0-8e7b-5cf9b0caecfb} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable: 255.255.255.255:9000 (255.255.255.255:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:40.627784 [ 33006 ] {2d6ec7d6-1a14-4217-bbf7-27020452c688} 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.3.20372.altinityantalya (altinity build)) (from [::1]:58462) (comment: 00167_settings_inside_query.sql) (query 1, line 1) (in query: SELECT min(number) FROM system.numbers WHERE toUInt64(number % 1000) IN (SELECT DISTINCT blockSize() FROM system.numbers SETTINGS max_block_size = 123, max_rows_to_read = 1000, read_overflow_mode = 'break') SETTINGS max_rows_to_read = 1000000, read_overflow_mode = 'break';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2afe46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:40.648895 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2afe46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:26:41.510690 [ 5476 ] {3f15a2f2-432a-4840-9f21-059d02a84dad} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int16 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 materialize(toInt16(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 176, line 192) (in query: SELECT materialize(toInt16(0)) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:41.533160 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int16 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 materialize(toInt16(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:42.581750 [ 5476 ] {b2ea12c0-1dfd-4507-8f8c-e3e1b9d6aaf7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope SELECT materialize(toInt16(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 179, line 195) (in query: SELECT materialize(toInt16(0)) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:42.593787 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope SELECT materialize(toInt16(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:42.793731 [ 5476 ] {0cf75898-717f-4a2e-bf78-901452c94e7d} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt16(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 180, line 196) (in query: SELECT materialize(toInt16(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:42.812617 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt16(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:43.026090 [ 5971 ] {8e1d2296-fb84-4f9c-aef9-eb1d533e028f} executeQuery: Code: 190. DB::Exception: Array arguments for function arrayL1Distance must have equal sizes: In scope SELECT L1Distance([0, 0], [1]). (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 36, line 97) (in query: SELECT L1Distance([0, 0], [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002114d4a9 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002113ed20 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002100feeb 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002100e9c1 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d8e3bc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:26:43.035338 [ 5971 ] {} TCPHandler: Code: 190. DB::Exception: Array arguments for function arrayL1Distance must have equal sizes: In scope SELECT L1Distance([0, 0], [1]). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002114d4a9 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002113ed20 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002100feeb 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002100e9c1 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d8e3bc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:26:43.201691 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:43.227572 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:43.254203 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5f7b3e 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316aaa35 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:43.255931 [ 34340 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5f7b3e 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316aaa35 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:43.282856 [ 5971 ] {f473444a-1134-4446-bd5d-2cf1a3bde4b8} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayL2Distance must be array.: In scope SELECT L2Distance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 37, line 98) (in query: SELECT L2Distance([1, 2], (3,4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000002126f7b2 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:26:43.307456 [ 5971 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayL2Distance must be array.: In scope SELECT L2Distance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000002126f7b2 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:26:43.515674 [ 34261 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:43.533118 [ 5971 ] {002dd079-acce-4069-aa22-4acbd871ee08} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayL2SquaredDistance must be array.: In scope SELECT L2SquaredDistance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 38, line 99) (in query: SELECT L2SquaredDistance([1, 2], (3,4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x00000000214c4f52 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:26:43.553424 [ 5971 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayL2SquaredDistance must be array.: In scope SELECT L2SquaredDistance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x00000000214c4f52 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:26:43.654578 [ 5971 ] {c527c3a9-5e41-4bc5-89f9-e566315e910a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([1, 2], [3, 4]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 39, line 100) (in query: SELECT LpDistance([1, 2], [3,4]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:43.658828 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([1, 2], [3, 4]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:26:43.830807 [ 5971 ] {505d7b33-37e0-4b55-88e0-9e56a383e4dd} executeQuery: Code: 69. DB::Exception: Second argument for function arrayLpDistance must be not less than one and not be an infinity: In scope SELECT LpDistance([1, 2], [3, 4], -1.). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 40, line 101) (in query: SELECT LpDistance([1, 2], [3,4], -1.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100d617 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184f536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021841620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021724d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217238c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9a43c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:26:43.856204 [ 5971 ] {} TCPHandler: Code: 69. DB::Exception: Second argument for function arrayLpDistance must be not less than one and not be an infinity: In scope SELECT LpDistance([1, 2], [3, 4], -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100d617 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184f536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021841620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021724d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217238c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9a43c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:26:44.160612 [ 5971 ] {cf1f8e9c-d88b-4e4d-9d30-b494f1d4718f} executeQuery: Code: 43. DB::Exception: Argument p of function arrayLpDistance must be numeric constant: In scope SELECT LpDistance([1, 2], [3, 4], 'aaa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 41, line 102) (in query: SELECT LpDistance([1, 2], [3,4], 'aaa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100d507 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184f536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021841620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021724d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217238c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9a43c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:26:44.189712 [ 5971 ] {} TCPHandler: Code: 43. DB::Exception: Argument p of function arrayLpDistance must be numeric constant: In scope SELECT LpDistance([1, 2], [3, 4], 'aaa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100d507 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184f536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021841620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021724d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217238c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9a43c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:26:44.465179 [ 5971 ] {debc3e14-fb18-47ca-97b2-d3d1e78c04a4} executeQuery: Code: 44. DB::Exception: Second argument for function arrayLpDistance must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41692) (comment: 02282_array_distance.sql) (query 42, line 103) (in query: SELECT LpDistance([1, 2], [3,4], materialize(2.7));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100d724 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002185b1c2 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184efcb 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021841620 9. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021724d8b 10. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217238c1 11. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9a43c 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 22. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 23. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 24. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:26:44.477821 [ 5971 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function arrayLpDistance must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100d724 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002185b1c2 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184efcb 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021841620 9. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021724d8b 10. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217238c1 11. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9a43c 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 22. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 23. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 24. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:26:46.221246 [ 5476 ] {fce7d410-e214-4c32-83a2-ca213726b814} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int32 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 materialize(toInt32(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 191, line 208) (in query: SELECT materialize(toInt32(0)) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:46.233611 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int32 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 materialize(toInt32(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:46.273133 [ 33000 ] {f9800d14-91f1-471d-a3cb-9b4596ee3c53} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 2, line 2) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTimeZone(N, 'UTC') as r FORMAT CSV;) 2025.07.13 02:26:46.303765 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:46.904059 [ 5476 ] {a867f4d2-d6fb-4c49-8d1e-4e713773c88f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope SELECT materialize(toInt32(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 194, line 211) (in query: SELECT materialize(toInt32(0)) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:46.919997 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope SELECT materialize(toInt32(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:47.162454 [ 5476 ] {c239831d-2e98-47a7-a8f4-284ebdff8e48} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt32(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 195, line 212) (in query: SELECT materialize(toInt32(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:47.186473 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt32(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:48.390030 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:48.417577 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:48.767259 [ 7056 ] {acbb8428-b33c-439d-9948-cc4f2ec0ff7e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 1, line 1) (in query: select * from format(CSV, 'd Date, s String', 'abcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:48.855024 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:48.968484 [ 7056 ] {27b1fbd3-abf6-4298-ad80-58a24883a1e8} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 2, line 2) (in query: select * from format(CSV, 'd Date, s String', '2bcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:48.974177 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.070589 [ 7056 ] {5cff50c7-0ccf-450c-8a0a-97e61acf56df} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 3, line 3) (in query: select * from format(CSV, 'd Date, s String', '20cdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.076145 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.161467 [ 5476 ] {55647425-7867-4440-b292-c6ef27fc4a98} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int64 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 materialize(toInt64(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 206, line 224) (in query: SELECT materialize(toInt64(0)) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.188613 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int64 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 materialize(toInt64(0)) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8cb 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.191991 [ 7056 ] {2723c5cf-6b7f-42ce-a1b1-498d4d906f6e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 4, line 4) (in query: select * from format(CSV, 'd Date, s String', '202defgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.204882 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.290468 [ 5476 ] {a873200f-79cb-4150-92c6-ea6cc19f156d} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float32, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT materialize(toInt64(0)) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 207, line 225) (in query: SELECT materialize(toInt64(0)) AS x, toFloat32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.293557 [ 7056 ] {201ece09-034e-483e-a90c-a3e9fc09bf0f} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 5, line 5) (in query: select * from format(CSV, 'd Date, s String', '2020efgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.297838 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float32, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT materialize(toInt64(0)) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.308169 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.391525 [ 7056 ] {976ccee0-767c-454f-864a-881103a0a91a} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 6, line 6) (in query: select * from format(CSV, 'd Date, s String', '20200fgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.409784 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.432720 [ 5476 ] {881c9fba-29e4-49c2-a5c9-2da4bd7d29ae} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float64, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT materialize(toInt64(0)) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 208, line 226) (in query: SELECT materialize(toInt64(0)) AS x, toFloat64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.440263 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float64, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT materialize(toInt64(0)) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002c520198 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:156: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002c51f8e5 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fc4 7. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.631394 [ 7056 ] {6d36f6b9-3902-48f3-86c8-2c77cbf3da5f} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 7, line 7) (in query: select * from format(CSV, 'd Date, s String', '202001gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.636147 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.641360 [ 5476 ] {d2df33f0-ddc0-4e46-8896-941f988e7f4c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope SELECT materialize(toInt64(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 209, line 227) (in query: SELECT materialize(toInt64(0)) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.647532 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope SELECT materialize(toInt64(0)) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b006355 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34341 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:26:49.743432 [ 7056 ] {3c5104c5-9d3c-47fb-ba17-17705879ed0e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 8, line 8) (in query: select * from format(CSV, 'd Date, s String', '2020010h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.768869 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:49.900754 [ 5476 ] {ccc2dac1-f345-4526-a50d-d68d5004b959} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt64(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 210, line 228) (in query: SELECT materialize(toInt64(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:49.905508 [ 5476 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT materialize(toInt64(0)) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:564: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52446e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002cd54bd0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:26:50.094525 [ 7056 ] {3469c06a-b2fa-46a0-9774-0a8acee2b3cf} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 10, line 10) (in query: select * from format(CSV, 'd Date, s String', 'abcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.110211 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.175010 [ 7056 ] {3942db34-e916-42da-b5a9-6ca17fb3ec29} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 11, line 11) (in query: select * from format(CSV, 'd Date, s String', '2bcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.178467 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.278160 [ 7056 ] {1eaa1a8f-7aa6-46f6-9f73-52c91b8d61aa} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 12, line 12) (in query: select * from format(CSV, 'd Date, s String', '20cd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.288375 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.371635 [ 7056 ] {f38dd47c-f9c1-411a-b25a-f72409e8f9b3} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 13, line 13) (in query: select * from format(CSV, 'd Date, s String', '202d-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.394204 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.599430 [ 7056 ] {a1211fd1-53e6-422c-95dc-7c60fd369936} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 14, line 14) (in query: select * from format(CSV, 'd Date, s String', '2020-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.602976 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.645068 [ 7056 ] {113a5dbb-ebab-4455-a107-096ea650a213} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 15, line 15) (in query: select * from format(CSV, 'd Date, s String', '2020-f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.647510 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.692428 [ 7056 ] {9fe968fd-f099-4830-acc7-11271e908754} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 16, line 16) (in query: select * from format(CSV, 'd Date, s String', '2020-f-g,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.694570 [ 5476 ] {f7f9238d-506f-499c-bc9c-d2cdbace9fb4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=853). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34432) (comment: 00735_long_conditional.sql) (query 215, line 234) (in query: SELECT materialize(toUInt8(0)) AS x, toInt16(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:50.695126 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.704090 [ 5476 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=853). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:50.781768 [ 7056 ] {54d7dc80-7162-490d-bd75-9962a0ef162b} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 17, line 17) (in query: select * from format(CSV, 'd Date, s String', '2020-0f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.850922 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.900766 [ 7056 ] {fc69eb72-0148-4bd2-9915-461be838b92d} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 18, line 18) (in query: select * from format(CSV, 'd Date, s String', '2020-01-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:50.904663 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.026088 [ 7056 ] {0a79086c-9d95-405e-a64e-1444bab2d9e9} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 19, line 19) (in query: select * from format(CSV, 'd Date, s String', '2020-01-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.064361 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.169098 [ 33000 ] {e118a9bd-6926-4ab2-9f16-debba639c27b} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 37, line 37) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:51.184387 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:51.188820 [ 7056 ] {79decb88-746a-4c72-a902-44268f5d79cf} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 20, line 20) (in query: select * from format(CSV, 'd Date, s String', '2020-1-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.196647 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.327176 [ 7056 ] {32da392d-97ab-42f0-8d9d-bb7efafc9fe4} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58594) (comment: 02916_date_text_parsing.sql) (query 21, line 21) (in query: select * from format(CSV, 'd Date, s String', '2020-1-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.349461 [ 7056 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000002892ab58 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002892a857 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c55d8b5 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c55d379 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:26:51.830343 [ 33000 ] {1f69fd7c-af59-43e1-879c-999f8166058b} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 42, line 42) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:51.839774 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:51.925329 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:52.448293 [ 33000 ] {198b9454-96fd-4049-b17c-d93d42b8db14} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 47, line 47) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:52.467854 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:53.608699 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:53.707421 [ 6126 ] {aa24958c-dc8a-4c83-8d55-8bc65c432628} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58602) (comment: 02477_age_date32.sql) (query 26, line 37) (in query: SELECT age('minute', toDate32('2015-08-18', 'UTC'), toDateTime('2015-08-19 00:00:00', 'UTC'), 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:53.742065 [ 33000 ] {f188dbab-3217-4277-b7cd-8f1e72422512} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 57, line 57) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:53.742285 [ 6126 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:26:53.750674 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:53.778124 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:54.498043 [ 33000 ] {9aa4a819-10c0-441c-92f9-07658c66b41a} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 62, line 62) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:54.511939 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:54.928401 [ 33000 ] {c69c74ec-f1cd-4317-9d2e-52f9318d8be4} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 67, line 67) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:54.933559 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:55.329523 [ 33000 ] {23c9cbd9-6968-4520-ae27-eb6286213bf5} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 72, line 72) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:55.336748 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:56.184144 [ 33000 ] {1d3645c1-8c8e-4e5e-a7af-87293f8b4fca} executeQuery: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 77, line 77) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:56.195688 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:56.885761 [ 33000 ] {74236a29-42b0-4129-a286-39968decd213} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 82, line 82) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:56.902621 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:57.059533 [ 33000 ] {f011fdfa-0e4e-44a7-9c03-82ff66702963} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 83, line 83) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:57.065404 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:57.126506 [ 33000 ] {ad069d2f-c1c0-48bd-9252-a29e722c086c} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 84, line 84) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:57.136461 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:58.109012 [ 33000 ] {ccf93b64-5e8c-4f0b-93a5-6d7271917140} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 92, line 92) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:58.111266 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:58.662609 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:58.724636 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:58.725453 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:26:58.880754 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:58.980720 [ 5382 ] {7d4cfd50-3004-4ed4-ba30-257dcdeeb961} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52366) (comment: 02473_functions_in_readonly_mode.sh) (query 1, line 1) (in query: SELECT * from format('TSV', '123')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58a96 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd578d5 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c0160 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:26:58.999384 [ 33000 ] {aee8964a-64fd-45c5-8954-b7690b8d71e1} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 97, line 97) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:59.012501 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:26:59.014019 [ 5382 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58a96 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd578d5 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c0160 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.103687 [ 34273 ] {4e126c0f-ba90-4a2f-a6fa-8341f0f8f01e} executeQuery: Code: 60. DB::Exception: Table test_5ws2oonn.ghdata does not exist. Maybe you meant test_15.data?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52374) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.129462 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5ws2oonn.ghdata does not exist. Maybe you meant test_15.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.386454 [ 5382 ] {944fb520-e268-49a3-8b5e-fa551e954789} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52384) (comment: 02473_functions_in_readonly_mode.sh) (query 1, line 1) (in query: INSERT INTO FUNCTION null('x String') (x) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58a96 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd578d5 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c0160 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce4d00 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.439232 [ 5382 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd58a96 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd578d5 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd25f7d 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4c5d87 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c0160 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce4d00 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.607484 [ 34273 ] {ca934833-258e-4a7e-aca1-8dc649dda7b0} executeQuery: Code: 60. DB::Exception: Could not find table: ghdata. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52392) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4dd74 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.636027 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4dd74 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:26:59.825370 [ 33000 ] {2ecfe83e-5f76-4dce-8ea7-8b7c26cd98d5} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 102, line 102) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:26:59.836053 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:00.017456 [ 5105 ] {acf86100-cc9b-4a9e-9cf8-f5540881cef8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52432) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:00.022805 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:00.454106 [ 5105 ] {07e551b8-4b64-4d86-9a1e-88e5757d96ed} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52452) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:00.471049 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:00.530296 [ 33000 ] {1b3b72ec-ade6-4a8f-971d-24ea9d92a9ed} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 107, line 107) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:00.535320 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:00.912215 [ 5105 ] {9586a4af-4153-4fc8-9b83-1e0d358771cd} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52466) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:00.940723 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:01.240271 [ 33000 ] {2ddc1bf8-efc1-4435-bba2-8524960e307d} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 112, line 112) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:01.258485 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:01.372675 [ 4529 ] {1020d31f-b7b4-42a7-908e-768c16d3a90f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52496) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:01.405006 [ 4529 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:27:01.863749 [ 33000 ] {4c06f115-b672-4939-8b31-d592479b6f5b} executeQuery: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 117, line 117) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 year, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:01.868272 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:02.035206 [ 3816 ] {b56bb894-f79d-4c0e-a9c3-fa6b0a158eca} executeQuery: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52412) (comment: 01018_ambiguous_column.sql) (query 13, line 16) (in query: SELECT dummy FROM one l JOIN one r ON l.dummy = dummy;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032147791 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:02.057905 [ 3816 ] {} TCPHandler: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032147791 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:02.431304 [ 33000 ] {daede410-39ec-41fb-9039-715ff77cb196} executeQuery: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 122, line 122) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 month, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:02.437387 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:03.812652 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:03.972520 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:03.998010 [ 33000 ] {d6777a53-0a49-4d8c-9be2-be9f8a6010bc} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 132, line 132) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 15 minute, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:04.006549 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:04.513959 [ 33000 ] {e100822b-d94f-4d58-828c-aca8788f6ea6} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 137, line 137) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:04.519504 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:04.862488 [ 3816 ] {adae0342-16e5-425f-895a-17c6b2689b17} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52586) (comment: 03166_skip_indexes_vertical_merge_1.sql) (query 7, line 21) (in query: EXPLAIN indexes = 1 SELECT count() FROM t_ind_merge_1 WHERE b < 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:34: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x0000000030e7ad5c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1515: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33828 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:811: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 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)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030e3b4f4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:05.008935 [ 3816 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:34: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x0000000030e7ad5c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1515: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33828 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:811: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 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)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030e3b4f4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:523: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcbe0ab 12. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcbc20c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:27:05.219990 [ 33000 ] {be0ef3ba-6a02-4214-87dc-0cd5c855b7b4} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 142, line 142) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:05.226148 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:06.575582 [ 33000 ] {ac4da0ff-ef17-427d-abb3-72466e35d876} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 152, line 152) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:06.593094 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:06.844988 [ 4938 ] {f12fddfc-cb68-47fe-adb5-362008c97493} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52580) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c08be60 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c2893c7 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c2891c8 7. ./build_docker/./src/Core/Settings.cpp:6487: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c18d0d8 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc3078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc2eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:06.851374 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c08be60 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c2893c7 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c2891c8 7. ./build_docker/./src/Core/Settings.cpp:6487: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c18d0d8 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc3078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc2eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:06.890686 [ 2824 ] {98b38256-4949-4988-9a3c-6ea3dc3e9515} executeQuery: Code: 36. DB::Exception: Could not decode the provided hash with 'bcrypt_hash'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52662) (comment: 03172_bcrypt_validation.sql) (query 2, line 3) (in query: CREATE USER `03172_user_invalid_bcrypt_hash` IDENTIFIED WITH bcrypt_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Access/AuthenticationData.cpp:250: DB::AuthenticationData::setPasswordHashBinary(std::vector> const&, bool) @ 0x000000002be0509a 6. ./build_docker/./src/Access/AuthenticationData.cpp:530: DB::AuthenticationData::fromAST(DB::ASTAuthenticationData const&, std::shared_ptr, bool) @ 0x000000002be08102 7. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:211: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f977883 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:06.900230 [ 2824 ] {} TCPHandler: Code: 36. DB::Exception: Could not decode the provided hash with 'bcrypt_hash'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Access/AuthenticationData.cpp:250: DB::AuthenticationData::setPasswordHashBinary(std::vector> const&, bool) @ 0x000000002be0509a 6. ./build_docker/./src/Access/AuthenticationData.cpp:530: DB::AuthenticationData::fromAST(DB::ASTAuthenticationData const&, std::shared_ptr, bool) @ 0x000000002be08102 7. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:211: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f977883 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:07.304031 [ 33000 ] {efe291ca-68c6-4f76-a526-c7cdbc52b8a0} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 157, line 157) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:07.325182 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:07.338788 [ 5105 ] {78a21475-cd4e-4cbe-8175-a94b6b8fe458} executeQuery: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52542) (comment: 02343_analyzer_lambdas.sql) (query 29, line 52) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT arrayMap(x -> compound_value.*, [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3441: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3e835 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:07.364196 [ 5105 ] {} TCPHandler: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3441: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3e835 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:07.536315 [ 4938 ] {eb28f639-3b18-4c0a-8ced-e2ca5949eb49} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52580) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcd32fc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7ab8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:07.577666 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcd32fc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7ab8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:08.164212 [ 5105 ] {1d95765e-50fc-4485-80dc-e79d18375d80} executeQuery: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52542) (comment: 02343_analyzer_lambdas.sql) (query 32, line 56) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long&, String&&) @ 0x000000002cc657af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2364: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4bd6f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10386 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:08.174783 [ 5105 ] {} TCPHandler: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long&, String&&) @ 0x000000002cc657af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2364: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4bd6f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10386 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:08.485027 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:08.553585 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:08.923570 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:09.084869 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:09.370173 [ 4938 ] {6b3280b0-c0af-4f3f-aaba-19383f302ebc} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52580) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c08be60 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c2893c7 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c2891c8 7. ./build_docker/./src/Core/Settings.cpp:6487: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c18d0d8 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc3078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc2eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:09.396584 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c08be60 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c2893c7 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c2891c8 7. ./build_docker/./src/Core/Settings.cpp:6487: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c18d0d8 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc3078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc2eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:09.941824 [ 2824 ] {80a67101-ab97-4668-8229-ccd7cec93923} registerStorageMergeTree: It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.07.13 02:27:10.696975 [ 5105 ] {42fe0920-12e6-4f3f-95f2-5443d6a9f324} executeQuery: Code: 36. DB::Exception: Lambda x -> (x + 1) is not allowed in expression context. In scope WITH (x, y) -> y AS lambda SELECT arrayMap(x -> (x + 1), [1, 2, 3]), (x -> (x + 1)), 1 AS x. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52542) (comment: 02343_analyzer_lambdas.sql) (query 46, line 86) (in query: -- lambda(tuple(x), x + 1) parsed as lambda definion but not as call of lambda defined in WITH WITH (x, y) -> y AS lambda SELECT arrayMap(lambda(tuple(x), x + 1), [1, 2, 3]), lambda(tuple(x), x + 1), 1 AS x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3847: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc120ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:10.720149 [ 5105 ] {} TCPHandler: Code: 36. DB::Exception: Lambda x -> (x + 1) is not allowed in expression context. In scope WITH (x, y) -> y AS lambda SELECT arrayMap(x -> (x + 1), [1, 2, 3]), (x -> (x + 1)), 1 AS x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3847: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc120ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:11.600834 [ 5105 ] {9ae4cca4-32d3-40bb-9956-54be372281a7} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(x) + 1) AS lambda. In scope x -> (lambda(x) + 1) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52542) (comment: 02343_analyzer_lambdas.sql) (query 50, line 97) (in query: WITH x -> (lambda(x) + 1) AS lambda SELECT lambda(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:11.608032 [ 5105 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(x) + 1) AS lambda. In scope x -> (lambda(x) + 1) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:11.769029 [ 5105 ] {633378c4-a137-4bfd-aa46-aaed56d71968} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda1(x) + 1) AS lambda. In scope x -> (lambda1(x) + 1) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52542) (comment: 02343_analyzer_lambdas.sql) (query 51, line 100) (in query: WITH x -> (lambda1(x) + 1) AS lambda, lambda AS lambda1 SELECT lambda(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:11.790498 [ 5105 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda1(x) + 1) AS lambda. In scope x -> (lambda1(x) + 1) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:27:13.953482 [ 5971 ] {170681b5-cfe9-4969-9df4-000695ca6f3b} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 2, line 5) (in query: -- test that the check which rejects hyperscan regexes with too big bounded repeats works -- {n} SELECT multiMatchAny('test', ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:13.958109 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:13.987387 [ 5971 ] {2d1d09af-30c8-42c9-89fa-b559d4327566} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{ 51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 3, line 9) (in query: SELECT multiMatchAny('test', ['.{ 51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:13.990477 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{ 51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.058151 [ 5971 ] {7a765f1a-e38c-454c-8a92-573e661392d7} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51 }']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 4, line 10) (in query: SELECT multiMatchAny('test', ['.{51 }']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.067537 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51 }']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.107182 [ 5971 ] {3e57b9bd-4c98-46bb-870c-ffb7dd962e2f} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['prefix.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 5, line 11) (in query: SELECT multiMatchAny('test', ['prefix.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.110742 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['prefix.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.155725 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:14.191104 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:14.208199 [ 5971 ] {d6359ae7-cb0e-460f-862b-67dab15ffa09} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51}.suffix']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 6, line 12) (in query: SELECT multiMatchAny('test', ['.{51}.suffix']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.212769 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51}.suffix']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.246104 [ 5971 ] {9e29a87e-ba96-45a8-9c12-d8b5cbad5777} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{4,4}midfix{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 7, line 13) (in query: SELECT multiMatchAny('test', ['.{4,4}midfix{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.251586 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{4,4}midfix{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.384236 [ 5971 ] {e3dacdbd-0850-4ab2-874b-fec44da46fe4} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 8, line 15) (in query: -- {n,} SELECT multiMatchAny('test', ['.{51,}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.394973 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.499993 [ 5971 ] {56dac588-1faa-4c42-897e-eb64ef2dd20c} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{ 51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 9, line 17) (in query: SELECT multiMatchAny('test', ['.{ 51,}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.507676 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{ 51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.578294 [ 5971 ] {4a0b7f7f-cd49-4661-acf1-4a606e1993ce} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51 ,}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 10, line 18) (in query: SELECT multiMatchAny('test', ['.{51 ,}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.582859 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51 ,}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.690398 [ 5971 ] {7ff1a9d9-3994-4a9d-8ab4-0d5dfc4f9bca} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51, }']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 11, line 19) (in query: SELECT multiMatchAny('test', ['.{51, }']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.695325 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51, }']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.755050 [ 5971 ] {5e213c88-8aa4-48c1-9c1d-d2242ba23662} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['prefix.{51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 12, line 20) (in query: SELECT multiMatchAny('test', ['prefix.{51,}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.760591 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['prefix.{51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.792221 [ 5971 ] {b38fd072-ea61-4560-a0dd-eb73939b15aa} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,}.suffix']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 13, line 21) (in query: SELECT multiMatchAny('test', ['.{51,}.suffix']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.796493 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,}.suffix']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.832929 [ 5971 ] {48bde0fc-1c4c-463f-b38f-193c3dc8f5e2} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{4,4}midfix{51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 14, line 22) (in query: SELECT multiMatchAny('test', ['.{4,4}midfix{51,}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.837113 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{4,4}midfix{51,}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.930873 [ 5971 ] {3fc9478b-a31f-4c29-8f6c-a969c13a9372} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{1,51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 15, line 24) (in query: -- {n,m} SELECT multiMatchAny('test', ['.{1,51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:14.938118 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{1,51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.006069 [ 5971 ] {4f81014c-6137-4aa6-b777-7c8eef502e16} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,52}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 16, line 26) (in query: SELECT multiMatchAny('test', ['.{51,52}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.010872 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,52}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.125319 [ 5971 ] {6513e291-5a01-412c-ae14-a4a5a13cd7c0} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{ 51,52}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 17, line 27) (in query: SELECT multiMatchAny('test', ['.{ 51,52}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.128130 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{ 51,52}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.212209 [ 5971 ] {9d2134e3-3111-4840-bd6a-2b1842593f66} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51 ,52}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 18, line 28) (in query: SELECT multiMatchAny('test', ['.{51 ,52}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.225806 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51 ,52}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.272340 [ 33000 ] {3eb1ec71-6aec-4220-87e7-adb51e1d7bdb} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 212, line 212) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:15.279270 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:15.307745 [ 5971 ] {d7c60a63-cc9e-4244-a8f5-987b6af2c82b} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51, 52}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 19, line 29) (in query: SELECT multiMatchAny('test', ['.{51, 52}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.312952 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51, 52}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.364319 [ 33000 ] {5c53dcec-06a2-478f-99f8-db099adf2ca0} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 213, line 213) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:15.383409 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:15.389397 [ 5971 ] {d973b329-fc7e-4ec4-bb6c-12f3b83d0753} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,52 }']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 20, line 30) (in query: SELECT multiMatchAny('test', ['.{51,52 }']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.392423 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{51,52 }']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.438359 [ 33000 ] {b9f7a586-680e-4af5-b6cc-c1e9dd723892} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 214, line 214) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:15.477143 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:15.511782 [ 5971 ] {87fd31b7-ecb0-425b-b5df-03730c9ac16f} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['prefix.{1,51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 21, line 31) (in query: SELECT multiMatchAny('test', ['prefix.{1,51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.523680 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['prefix.{1,51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.641297 [ 5971 ] {97618c53-7b4b-4b66-b017-352a3359e2a2} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{1,51}.suffix']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 22, line 32) (in query: SELECT multiMatchAny('test', ['.{1,51}.suffix']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.657482 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{1,51}.suffix']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.735514 [ 5971 ] {ba731f81-a265-4822-9685-4f5ac0a2a259} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{4,4}midfix{1,51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 23, line 33) (in query: SELECT multiMatchAny('test', ['.{4,4}midfix{1,51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.743730 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('test', ['.{4,4}midfix{1,51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:15.888113 [ 33000 ] {d2f69e40-e8a7-4d00-9aac-e837c8648fcf} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 217, line 217) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:15.892271 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:15.946590 [ 33000 ] {01e77e8f-e9f8-4f99-b982-a946fa74a1c6} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 218, line 218) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:15.955727 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:16.005792 [ 33000 ] {04afb5b8-e88e-4ec2-b2d8-7d42c5c9c752} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 219, line 219) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:16.016864 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:16.271773 [ 5971 ] {52279a13-017c-4551-8b38-ac594fb2b358} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('Hallo Welt', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 26, line 40) (in query: SELECT multiMatchAny('Hallo Welt', ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:16.271895 [ 33000 ] {faa80519-94dc-460d-8499-51ceffb73899} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 222, line 222) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:16.293101 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAny('Hallo Welt', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d104371 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:16.296960 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:16.483560 [ 5971 ] {d38ec3a3-ad47-4834-99f5-3bd3386ee7b5} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 27, line 41) (in query: SELECT multiMatchAny(c, ['.{51}']) FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d10453d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:16.493050 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d10453d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:16.780019 [ 5971 ] {9435f83e-736f-48db-b13d-17acc969b48d} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAnyIndex('Hallo Welt', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 28, line 43) (in query: SELECT multiMatchAnyIndex('Hallo Welt', ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01bf3d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:16.800425 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAnyIndex('Hallo Welt', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01bf3d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:17.004100 [ 5971 ] {333a6404-0bb5-4cb4-b180-e540b546f2a3} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 29, line 44) (in query: SELECT multiMatchAnyIndex(c, ['.{51}']) FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01c0f1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:17.007207 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01c0f1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:17.166321 [ 5971 ] {7e218eb3-0104-41e6-a48b-3a272b32c0a5} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAllIndices('Hallo Welt', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 30, line 46) (in query: SELECT multiMatchAllIndices('Hallo Welt', ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f016b1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:17.194981 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiMatchAllIndices('Hallo Welt', ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f016b1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:17.474896 [ 5971 ] {62bce08b-1d60-4881-8acc-a5022d7a0b05} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 31, line 47) (in query: SELECT multiMatchAllIndices(c, ['.{51}']) FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f016d61 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:17.510961 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f016d61 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:17.697573 [ 5971 ] {e72583ff-4253-4aa5-8986-df1a3972d8f3} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiFuzzyMatchAny('Hallo Welt', 1, ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 32, line 49) (in query: SELECT multiFuzzyMatchAny('Hallo Welt', 1, ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00d4b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:17.703159 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiFuzzyMatchAny('Hallo Welt', 1, ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00d4b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:17.903112 [ 5971 ] {5db0da2f-11ee-4613-ba4e-f6a6815c0d70} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 33, line 50) (in query: SELECT multiFuzzyMatchAny(c, 1, ['.{51}']) FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00d67d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:17.908821 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00d67d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:18.069916 [ 5971 ] {f0451d9e-6d27-4051-b93c-eb33f974f4c6} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiFuzzyMatchAnyIndex('Hallo Welt', 1, ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 34, line 52) (in query: SELECT multiFuzzyMatchAnyIndex('Hallo Welt', 1, ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f012ef1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:18.072994 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiFuzzyMatchAnyIndex('Hallo Welt', 1, ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f012ef1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:18.216485 [ 5971 ] {b3a4da15-2578-45f1-9971-5d3711ff2742} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 35, line 53) (in query: SELECT multiFuzzyMatchAnyIndex(c, 1, ['.{51}']) FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0130b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:18.219967 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0130b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:18.394566 [ 5971 ] {54ea0b74-85b9-4e1c-a0a5-d1c76d400d5e} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiFuzzyMatchAllIndices('Hallo Welt', 1, ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 36, line 55) (in query: SELECT multiFuzzyMatchAllIndices('Hallo Welt', 1, ['.{51}']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00475d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:18.409264 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'.: In scope SELECT multiFuzzyMatchAllIndices('Hallo Welt', 1, ['.{51}']). (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00475d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:18.675727 [ 5971 ] {dea9bcf2-264c-4add-a522-c5b2aa0f2e7c} executeQuery: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32792) (comment: 02560_regexp_denial_of_service.sql) (query 37, line 56) (in query: SELECT multiFuzzyMatchAllIndices(c, 1, ['.{51}']) FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0049a1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:18.684114 [ 5971 ] {} TCPHandler: Code: 447. DB::Exception: Regular expression evaluation in vectorscan will be too slow. To ignore this error, disable setting 'reject_expensive_hyperscan_regexps'. (HYPERSCAN_CANNOT_SCAN_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0049a1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:27:19.107478 [ 33000 ] {f6aab121-9ca5-434f-a24b-f5efe8671728} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 242, line 242) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:19.112684 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:19.363171 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:19.433587 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:19.485129 [ 32979 ] {} DynamicQueryHandler: Code: 516. DB::Exception: u01_0317424837: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:19.822692 [ 33000 ] {4fe2acf0-5101-499c-947f-cb3252c67929} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 247, line 247) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:19.828955 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:20.317927 [ 33000 ] {39f87977-b343-45ff-993b-6d7966a6e64a} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 252, line 252) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:20.339646 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:21.095727 [ 33000 ] {d45e803b-53f6-48f0-bc44-d5cf1e15c269} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 257, line 257) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:21.099394 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:21.757832 [ 33000 ] {718bbe27-7eaf-473a-b51a-d7a80185e6d0} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 262, line 262) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:21.762505 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:22.385423 [ 33000 ] {50af6670-e225-493c-a7d1-1d5a1b65a7f7} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 267, line 267) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:22.396109 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:23.245629 [ 33000 ] {1163f17f-aeb6-4c77-a763-a3db7163670d} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 272, line 272) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:23.250684 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:23.934301 [ 34275 ] {a47a74f2-e874-4c25-ac75-3c94fe21a3e6} executeQuery: Code: 36. DB::Exception: Unsupported value 2 of the `function_visible_width_behavior` setting: In scope SELECT visibleWidth('ClickHouse是一个很好的数æ®åº“') SETTINGS function_visible_width_behavior = 2. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37196) (comment: 02970_visible_width_behavior.sql) (query 4, line 4) (in query: SELECT visibleWidth('ClickHouse是一个很好的数æ®åº“') SETTINGS function_visible_width_behavior = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::FunctionVisibleWidth::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dabf81 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:23.955143 [ 33000 ] {483b43b4-1002-4c8a-ae7a-a89c5e66f032} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 277, line 277) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:23.974611 [ 34275 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported value 2 of the `function_visible_width_behavior` setting: In scope SELECT visibleWidth('ClickHouse是一个很好的数æ®åº“') SETTINGS function_visible_width_behavior = 2. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::FunctionVisibleWidth::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dabf81 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:23.980329 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:23.996682 [ 34275 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:24.012985 [ 34275 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:27:24.436860 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:24.499462 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:24.632844 [ 33000 ] {91dafef9-a60c-4ee8-a7c7-6d365ba2e45c} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 282, line 282) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:24.638693 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:24.661888 [ 2824 ] {b5f12d67-10cf-4a4a-85ed-9314eefe64af} executeQuery: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60872) (comment: 02439_merge_selecting_partitions.sql) (query 14, line 20) (in query: optimize table rmt partition tuple(123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6144: 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 @ 0x0000000030685734 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6306: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000306808e8 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:24.665133 [ 2824 ] {} TCPHandler: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6144: 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 @ 0x0000000030685734 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6306: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000306808e8 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:25.341868 [ 33000 ] {b384a095-c7d4-4b86-9a83-0747f40497d8} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 287, line 287) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:25.347750 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:25.728418 [ 5476 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: Expected authentication with SSH key. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:1754: DB::TCPHandler::receiveHello() @ 0x00000000316ba675 6. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:25.757367 [ 5476 ] {} ServerErrorHandler: Code: 516. DB::Exception: Expected authentication with SSH key. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:1754: DB::TCPHandler::receiveHello() @ 0x00000000316ba675 6. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:25.908446 [ 33000 ] {0fc4fcb6-101f-4f5e-8368-8e54a0e06d87} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=876). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 291, line 291) (in query: SELECT 'SELECT subtractWeeks(N, 1, \'Asia/Istanbul\')';) 2025.07.13 02:27:25.911841 [ 33000 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=876). (CANNOT_SCHEDULE_TASK) 2025.07.13 02:27:26.080357 [ 33000 ] {bebb0131-97c2-48d7-bbac-b117bd2beffe} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 292, line 292) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:26.111725 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:26.771351 [ 33000 ] {c76d42ad-33b0-468f-88e6-c4653cbf5334} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 297, line 297) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:26.789743 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:27.374003 [ 33000 ] {e421ba3f-cc52-4b38-8588-c74c4320ba05} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 302, line 302) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:27.379277 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:27.834748 [ 33000 ] {df462c15-1e30-4ed3-a219-06062887c202} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 307, line 307) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:27.840138 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:28.170284 [ 34277 ] {a8822b5a-d418-4d0c-b575-5a70bb7690bd} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.join, because some tables depend on it: test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f), test_zk5s8hlx.s, test_zk5s8hlx.dict2. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01160_table_dependencies.sh) (in query: /* ddl_entry=query-0000000010 */ RENAME TABLE join TO join1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1512: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002d60820a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:150: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04269 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:129: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04175 16. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.229276 [ 34277 ] {a8822b5a-d418-4d0c-b575-5a70bb7690bd} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.join, because some tables depend on it: test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f), test_zk5s8hlx.s, test_zk5s8hlx.dict2. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37298) (comment: 01160_table_dependencies.sh) (query 1, line 1) (in query: rename table join to join1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1512: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002d60820a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:150: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04269 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:129: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04175 16. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.243391 [ 34277 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.join, because some tables depend on it: test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f), test_zk5s8hlx.s, test_zk5s8hlx.dict2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1512: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002d60820a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:150: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04269 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:129: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04175 16. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.374948 [ 33000 ] {a43f10ba-81ae-41a7-a6d2-6ef1813c1485} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 312, line 312) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:28.391210 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:28.710942 [ 34275 ] {1e97721c-5c2c-483c-9b8e-12f12aa79f3e} executeQuery: Code: 10. DB::Exception: Not found column key2 in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 25, line 31) (in query: SELECT t1.key FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND 0 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002cb2a0de 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1722: _ZZN2DB12_GLOBAL__N_131buildQueryPlanForJoinNodeLegacyERKNSt3__110shared_ptrINS_14IQueryTreeNodeEEENS_17JoinTreeQueryPlanES7_RKNS1_13unordered_setINS1_12basic_stringIcNS1_11char_traitsIcEENS1_9allocatorIcEEEENS1_4hashISE_EENS1_8equal_toISE_EENSC_ISE_EEEERNS2_INS_14PlannerContextEEERKNS_15SelectQueryInfoEENK3$_1clINS1_6vectorIPKNS_10ActionsDAG4NodeENSC_ISZ_EEEEEEDaRSW_RNS_9QueryPlanERNS8_INS2_INS_9FutureSetEEENSF_IS16_EENSH_IS16_EENSC_IS16_EEEERKT_ @ 0x000000002ddb9793 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1734: 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&) @ 0x000000002ddb54fc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.715652 [ 34275 ] {} TCPHandler: Code: 10. DB::Exception: Not found column key2 in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002cb2a0de 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1722: _ZZN2DB12_GLOBAL__N_131buildQueryPlanForJoinNodeLegacyERKNSt3__110shared_ptrINS_14IQueryTreeNodeEEENS_17JoinTreeQueryPlanES7_RKNS1_13unordered_setINS1_12basic_stringIcNS1_11char_traitsIcEENS1_9allocatorIcEEEENS1_4hashISE_EENS1_8equal_toISE_EENSC_ISE_EEEERNS2_INS_14PlannerContextEEERKNS_15SelectQueryInfoEENK3$_1clINS1_6vectorIPKNS_10ActionsDAG4NodeENSC_ISZ_EEEEEEDaRSW_RNS_9QueryPlanERNS8_INS2_INS_9FutureSetEEENSF_IS16_EENSH_IS16_EENSC_IS16_EEEERKT_ @ 0x000000002ddb9793 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1734: 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&) @ 0x000000002ddb54fc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.759662 [ 5476 ] {f5972001-c9b2-4a72-bab3-5ee1fb4895e1} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.join (e98c6469-81ba-44c4-af86-99c4525e686b), because some tables depend on it: test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f), test_zk5s8hlx.s, test_zk5s8hlx.dict2. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01160_table_dependencies.sh) (in query: /* ddl_entry=query-0000000011 */ DROP TABLE test_zk5s8hlx.join SYNC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.825510 [ 5476 ] {f5972001-c9b2-4a72-bab3-5ee1fb4895e1} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.join (e98c6469-81ba-44c4-af86-99c4525e686b), because some tables depend on it: test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f), test_zk5s8hlx.s, test_zk5s8hlx.dict2. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37308) (comment: 01160_table_dependencies.sh) (query 1, line 1) (in query: drop table join), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:27:28.861981 [ 5476 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.join (e98c6469-81ba-44c4-af86-99c4525e686b), because some tables depend on it: test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f), test_zk5s8hlx.s, test_zk5s8hlx.dict2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:27:29.029239 [ 33000 ] {d84aecaf-b3e4-4285-adf4-1558d7bab9e8} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 317, line 317) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.13 02:27:29.035501 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:29.472478 [ 5476 ] {94cf3e28-0fc1-4712-8e12-ed217f04369a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.dict1 (46bff5a6-8205-4808-887a-0c1e4463acdd), because some tables depend on it: test_zk5s8hlx.join, test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f). (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01160_table_dependencies.sh) (in query: /* ddl_entry=query-0000000012 */ DETACH DICTIONARY test_zk5s8hlx.dict1 PERMANENTLY SYNC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1512: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002d60820a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:253: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb304e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:27:29.490891 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:29.506581 [ 5476 ] {94cf3e28-0fc1-4712-8e12-ed217f04369a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.dict1 (46bff5a6-8205-4808-887a-0c1e4463acdd), because some tables depend on it: test_zk5s8hlx.join, test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f). (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37738) (comment: 01160_table_dependencies.sh) (query 1, line 1) (in query: detach dictionary dict1 permanently), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1512: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002d60820a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:253: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb304e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:27:29.525407 [ 5476 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_zk5s8hlx.dict1 (46bff5a6-8205-4808-887a-0c1e4463acdd), because some tables depend on it: test_zk5s8hlx.join, test_zk5s8hlx.t (3daafaed-d73d-4ca2-8310-e67adeceeb3f). (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1512: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002d60820a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:253: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb304e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:27:29.591867 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:30.300597 [ 29256 ] {c7dd2568-d498-41dc-9e94-adee463081ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37152) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 28, line 80) (in query: select splitByString('IN', query)[-1] from system.query_log where event_date >= yesterday() and event_time > now() - interval 1 hour and not is_initial_query and query not like '%system%query_log%' and query like concat('%', currentDatabase(), '%AS%id_00%') and type = 'QueryFinish' order by query;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:27:30.346815 [ 29256 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:27:31.364021 [ 4529 ] {1e78fbac-017c-44e2-b95b-0ea422e40d38} executeQuery: Code: 81. DB::Exception: Database test_zk5s8hlx_2 does not exist. Maybe you meant test_zk5s8hlx?. (UNKNOWN_DATABASE) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01160_table_dependencies.sh) (in query: /* ddl_entry=query-0000000013 */ RENAME TABLE t TO test_zk5s8hlx_2.t), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa14d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:157: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd044a2 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:129: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04175 15. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:31.410223 [ 4529 ] {1e78fbac-017c-44e2-b95b-0ea422e40d38} executeQuery: Code: 81. DB::Exception: Database test_zk5s8hlx_2 does not exist. Maybe you meant test_zk5s8hlx?. (UNKNOWN_DATABASE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37804) (comment: 01160_table_dependencies.sh) (query 1, line 1) (in query: rename table t to test_zk5s8hlx_2.t), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa14d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:157: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd044a2 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:129: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04175 15. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:31.427042 [ 4529 ] {} TCPHandler: Code: 81. DB::Exception: Database test_zk5s8hlx_2 does not exist. Maybe you meant test_zk5s8hlx?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa14d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:157: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd044a2 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:129: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dd04175 15. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dd0214c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:31.482217 [ 7056 ] {40a80c4c-185b-49ac-8d74-02e89144c9bc} 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.3.20372.altinityantalya (altinity build)) (from [::1]:37818) (comment: 03047_on_fly_mutations_projections.sql) (query 3, line 8) (in query: CREATE TABLE t_update_projections (`id` UInt64, `v` UInt64, PROJECTION proj (SELECT sum(v))) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/t_update_projections', '1') ORDER BY tuple() SETTINGS index_granularity = 12675, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.038927655667066574, replace_long_file_name_to_hash = true, max_file_name_length = 106, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 85813898, compact_parts_max_granules_to_buffer = 236, compact_parts_merge_max_bytes_to_prefetch_part = 18217612, merge_max_block_size = 19857, 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 = 19, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26926167, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 17917, primary_key_compress_block_size = 11673, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:31.503169 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:32.097005 [ 5476 ] {6e76dca6-cbb9-4172-87b6-3837d3f8def5} executeQuery: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02517_executable_pool_bad_input_query.sql) (in query: /* ddl_entry=query-0000000231 */ CREATE TABLE test_5.test_table UUID '5f39a98d-997d-43a3-8eb2-be44c806a598' (`value` String) ENGINE = ExecutablePool('nonexist.py', 'TabSeparated', foobar)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:32.131011 [ 5476 ] {6e76dca6-cbb9-4172-87b6-3837d3f8def5} executeQuery: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37834) (comment: 02517_executable_pool_bad_input_query.sql) (query 1, line 1) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', (foobar));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:32.134075 [ 5476 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:32.385854 [ 4938 ] {635c91eb-99a0-48af-963c-b45946b7a220} PushingToViews: Failed to push block to view test_13.view (6b8a7bfb-a964-43df-9e81-389b4a564333), Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp'] 2025.07.13 02:27:32.387897 [ 4938 ] {635c91eb-99a0-48af-963c-b45946b7a220} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37866) (comment: 02125_constant_if_condition_and_not_existing_column.sql) (query 3, line 5) (in query: insert into test values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:27:32.404405 [ 4938 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:27:33.691508 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:33.780106 [ 3766 ] {aa723b79-0f52-451c-bd77-f5c33e716aa1} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 68645.818827 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33932) (comment: 03272_json_to_json_alter.gen.sql) (query 51, line 66) (in query: insert into test select number, multiIf(number < 10000, '{"k2" : 42}', number < 30000, '{"k3" : 42}', number < 60000, '{"k4" : 42}', number < 100000, '{"k1" : 42}', '{"k1" : 42, "k2" : 42, "k3" : 42, "k4" : 42}') from numbers(150000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000002d63c54f 5. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def371c 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:27:33.796151 [ 3766 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 68645.818827 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000002d63c54f 5. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def371c 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:27:34.107750 [ 5476 ] {} DynamicQueryHandler: Code: 516. DB::Exception: u01_0317424837: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:34.825750 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:34.828873 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:35.193516 [ 5476 ] {cb8e8f4a-6789-4220-910d-2adacfd3b52b} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 102 (IDENTIFIED): IDENTIFIED plaintext_password by '8'. Expected one of: NO_PASSWORD, PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42406) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost IDENTIFIED WITH plaintext_password by '7', IDENTIFIED plaintext_password by '8'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:35.195363 [ 5476 ] {cb8e8f4a-6789-4220-910d-2adacfd3b52b} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 102 (IDENTIFIED): IDENTIFIED plaintext_password by '8'. Expected one of: NO_PASSWORD, PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:35.401468 [ 34275 ] {4606b195-9b8f-4b28-a115-fdd567d9fb70} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 49, line 60) (in query: -- `e + 1` is UInt16, but `t1.id == t2.id AND e + 1` is UInt8 SELECT DISTINCT t1.key, toUInt8(t1.id) as e FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND e + 1 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:35.426429 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:35.763271 [ 7056 ] {78ad69e9-bcd9-4e09-b3bb-8bc277091a94} executeQuery: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_dic6n2sv.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37860) (comment: 01297_alter_distributed.sql) (query 17, line 28) (in query: select CounterID, dummy1 from merge_distributed where dummy1 <> '' limit 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d1520af 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d145c10 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14642d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14860a 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:48: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x00000000320f5212 21. ./build_docker/./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 @ 0x000000002f9e743e 22. ./build_docker/./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) @ 0x000000002f9e5695 23. ./build_docker/./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)>) @ 0x000000002f9e76b4 24. ./build_docker/./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) @ 0x000000002f9d04ae 25. ./build_docker/./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) @ 0x000000003039cf73 26. ./build_docker/./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) @ 0x000000002ddac77e 27. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 28. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 29. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 2025.07.13 02:27:35.775148 [ 7056 ] {} TCPHandler: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_dic6n2sv.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d1520af 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d145c10 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14642d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d14860a 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1509fb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29162 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:48: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x00000000320f5212 21. ./build_docker/./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 @ 0x000000002f9e743e 22. ./build_docker/./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) @ 0x000000002f9e5695 23. ./build_docker/./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)>) @ 0x000000002f9e76b4 24. ./build_docker/./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) @ 0x000000002f9d04ae 25. ./build_docker/./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) @ 0x000000003039cf73 26. ./build_docker/./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) @ 0x000000002ddac77e 27. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 28. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 29. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 2025.07.13 02:27:35.961000 [ 5379 ] {e02ffdcf-c7ad-4268-97a9-e1660bd69c54} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 103 (IDENTIFIED): IDENTIFIED WITH plaintext_password by '8'. Expected one of: NO_PASSWORD, PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42416) (comment: 03174_multiple_authentication_methods.sh) (in query: CREATE USER u01_0317424837 ON CLUSTER test_shard_localhost IDENTIFIED WITH plaintext_password by '7', IDENTIFIED WITH plaintext_password by '8'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:35.963287 [ 5379 ] {e02ffdcf-c7ad-4268-97a9-e1660bd69c54} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 103 (IDENTIFIED): IDENTIFIED WITH plaintext_password by '8'. Expected one of: NO_PASSWORD, PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:36.709735 [ 33000 ] {d5345352-2587-4352-a8a7-1946d9dc3a1d} executeQuery: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 367, line 367) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.07.13 02:27:36.714233 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:36.755145 [ 33000 ] {c6e05d53-5de6-4d20-914d-7d5307239a03} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 368, line 368) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.07.13 02:27:36.762591 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:36.850289 [ 33000 ] {d3f61933-e5a9-4d12-80ca-5b8054969b0b} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 369, line 369) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.07.13 02:27:36.857322 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:36.958116 [ 34275 ] {fed9dd07-4064-4b40-b979-f0307b15f834} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 55, line 69) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:36.962483 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.129252 [ 34275 ] {43e323ad-2302-4b05-a9c7-e02fa0c25e93} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 56, line 70) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.143132 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.258300 [ 34275 ] {ad02a5af-ad52-446b-9924-f3cd01597ed3} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 57, line 71) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id + 2 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.291275 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.363950 [ 34275 ] {a2797cd0-7cd3-4d6c-8661-4702b05a43d9} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 58, line 72) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id + 2 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.370012 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.447105 [ 3648 ] {8c52bf3d-9a9c-4bc2-857e-c7792a521884} executeQuery: Code: 36. DB::Exception: Authentication method 'no_password' cannot co-exist with other authentication methods. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ADD IDENTIFIED WITH plaintext_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:126: DB::(anonymous namespace)::updateUserFromQueryImpl(DB::User&, DB::ASTCreateUserQuery const&, std::vector>, std::shared_ptr const&, std::optional const&, std::optional const&, std::optional const&, std::optional const&, bool, bool, bool, bool, bool, unsigned long) @ 0x000000002f97b8fd 6. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:261: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&) @ 0x000000002f97c8f7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002be52cd9 8. ./build_docker/./src/Access/AccessControl.cpp:571: DB::AccessControl::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)> const&, bool) @ 0x000000002bccdd93 9. ./build_docker/./src/Access/IAccessStorage.cpp:412: DB::IAccessStorage::update(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, std::function (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)> const&, bool) @ 0x000000002bdf5680 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:275: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f978a9a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5cb52f 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5bf9d6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.451251 [ 3648 ] {8c52bf3d-9a9c-4bc2-857e-c7792a521884} DDLWorker: Query /* ddl_entry=query-0000000018 */ ALTER USER u01_0317424837 ADD IDENTIFIED WITH plaintext_password wasn't finished successfully: Code: 36. DB::Exception: Authentication method 'no_password' cannot co-exist with other authentication methods. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:126: DB::(anonymous namespace)::updateUserFromQueryImpl(DB::User&, DB::ASTCreateUserQuery const&, std::vector>, std::shared_ptr const&, std::optional const&, std::optional const&, std::optional const&, std::optional const&, bool, bool, bool, bool, bool, unsigned long) @ 0x000000002f97b8fd 6. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:261: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&) @ 0x000000002f97c8f7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002be52cd9 8. ./build_docker/./src/Access/AccessControl.cpp:571: DB::AccessControl::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)> const&, bool) @ 0x000000002bccdd93 9. ./build_docker/./src/Access/IAccessStorage.cpp:412: DB::IAccessStorage::update(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, std::function (std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&)> const&, bool) @ 0x000000002bdf5680 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:275: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f978a9a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5cb52f 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5bf9d6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:37.504443 [ 10341 ] {fbc58f58-8adb-458e-ab3c-c6c7818793d5} executeQuery: Code: 36. DB::Exception: There was an error on [localhost:9000]: Code: 36. DB::Exception: Authentication method 'no_password' cannot co-exist with other authentication methods. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42460) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost ADD IDENTIFIED WITH plaintext_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e29aa5a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6243a1 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.506877 [ 10341 ] {fbc58f58-8adb-458e-ab3c-c6c7818793d5} DynamicQueryHandler: Code: 36. DB::Exception: There was an error on [localhost:9000]: Code: 36. DB::Exception: Authentication method 'no_password' cannot co-exist with other authentication methods. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e29aa5a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6243a1 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:37.636600 [ 10341 ] {b3fbd834-9faa-4f24-a278-e8c5f98eb392} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 106 (no_password): no_password. Expected one of: PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42464) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost ADD IDENTIFIED WITH plaintext_password by '8', no_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.637878 [ 10341 ] {b3fbd834-9faa-4f24-a278-e8c5f98eb392} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 106 (no_password): no_password. Expected one of: PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:37.795234 [ 10341 ] {53254ebb-aed1-420a-92bf-8ed5b3eb7d6c} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 79 (no_password): no_password. Expected one of: PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42478) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost ADD IDENTIFIED WITH no_password), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:37.799507 [ 10341 ] {53254ebb-aed1-420a-92bf-8ed5b3eb7d6c} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 79 (no_password): no_password. Expected one of: PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:39.051204 [ 34275 ] {9179295a-310b-4120-81bc-93f9d0bc97b1} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 63, line 79) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.key;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.061238 [ 34275 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.128140 [ 34275 ] {3478e44a-5ff1-4f91-86dc-b369802c2e2f} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 64, line 80) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.key;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.131765 [ 34275 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.407027 [ 3885 ] {71bdc85b-ac76-436e-a8c0-8f794626932e} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 76 (BY): BY '1';. Expected one of: NO_PASSWORD, PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48514) (comment: 03174_multiple_authentication_methods.sh) (in query: CREATE USER u01_0317424837 ON CLUSTER test_shard_localhost IDENTIFIED WITH BY '1';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.409391 [ 3885 ] {71bdc85b-ac76-436e-a8c0-8f794626932e} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 76 (BY): BY '1';. Expected one of: NO_PASSWORD, PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:39.506276 [ 4938 ] {5a47d27a-71e2-4af4-97b6-7038b021f8e4} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 60 (ADD): ADD IDENTIFIED WITH plaintext_password by '1'. Expected one of: NOT IDENTIFIED, IDENTIFIED, HOST, SettingsProfileElements, SETTINGS, SETTING, PROFILES, PROFILE, DEFAULT ROLE, GRANTEES, DEFAULT DATABASE, IN, VALID UNTIL, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48528) (comment: 03174_multiple_authentication_methods.sh) (in query: CREATE USER u01_0317424837 ON CLUSTER test_shard_localhost ADD IDENTIFIED WITH plaintext_password by '1'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.508489 [ 4938 ] {5a47d27a-71e2-4af4-97b6-7038b021f8e4} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 60 (ADD): ADD IDENTIFIED WITH plaintext_password by '1'. Expected one of: NOT IDENTIFIED, IDENTIFIED, HOST, SettingsProfileElements, SETTINGS, SETTING, PROFILES, PROFILE, DEFAULT ROLE, GRANTEES, DEFAULT DATABASE, IN, VALID UNTIL, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:39.717275 [ 4938 ] {2030f964-3ca1-41e5-b16f-b9e71e95210d} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 105 (end of query): . Expected one of: PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48536) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost ADD IDENTIFIED WITH plaintext_password by '1',), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.720202 [ 4938 ] {2030f964-3ca1-41e5-b16f-b9e71e95210d} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 105 (end of query): . Expected one of: PLAINTEXT_PASSWORD, SHA256_PASSWORD, DOUBLE_SHA1_PASSWORD, LDAP, KERBEROS, SSL_CERTIFICATE, BCRYPT_PASSWORD, SSH_KEY, HTTP, JWT, SHA256_HASH, DOUBLE_SHA1_HASH, BCRYPT_HASH, BY, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:39.722314 [ 3900 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:39.810304 [ 34268 ] {2c84dec4-d9c8-4be6-b068-096d3341afad} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 90 (by): by '1'. Expected end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48542) (comment: 03174_multiple_authentication_methods.sh) (in query: CREATE USER u01_0317424837 ON CLUSTER test_shard_localhost IDENTIFIED plaintext_password by '1'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.821504 [ 34268 ] {2c84dec4-d9c8-4be6-b068-096d3341afad} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 90 (by): by '1'. Expected end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:39.958823 [ 3900 ] {e5aaabb1-a2a4-4058-8753-6058938911d7} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 60 (RESET): RESET AUTHENTICATION METHODS TO NEW. Expected one of: NOT IDENTIFIED, IDENTIFIED, HOST, SettingsProfileElements, SETTINGS, SETTING, PROFILES, PROFILE, DEFAULT ROLE, GRANTEES, DEFAULT DATABASE, IN, VALID UNTIL, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48550) (comment: 03174_multiple_authentication_methods.sh) (in query: CREATE USER u01_0317424837 ON CLUSTER test_shard_localhost RESET AUTHENTICATION METHODS TO NEW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:39.962022 [ 3900 ] {e5aaabb1-a2a4-4058-8753-6058938911d7} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 60 (RESET): RESET AUTHENTICATION METHODS TO NEW. Expected one of: NOT IDENTIFIED, IDENTIFIED, HOST, SettingsProfileElements, SETTINGS, SETTING, PROFILES, PROFILE, DEFAULT ROLE, GRANTEES, DEFAULT DATABASE, IN, VALID UNTIL, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:40.005215 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:40.013025 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:40.036034 [ 34268 ] {0dceb0c8-0ae5-4dcf-871c-c4c3385e78e1} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 63 (NOT): NOT IDENTIFIED. Expected one of: IDENTIFIED, ALL PROFILES, ALL SETTINGS, PROFILES, PROFILE, SETTINGS, SETTING, HOST, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48552) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost ADD NOT IDENTIFIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:40.043450 [ 34268 ] {0dceb0c8-0ae5-4dcf-871c-c4c3385e78e1} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 63 (NOT): NOT IDENTIFIED. Expected one of: IDENTIFIED, ALL PROFILES, ALL SETTINGS, PROFILES, PROFILE, SETTINGS, SETTING, HOST, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:40.190617 [ 3885 ] {dc44896c-31f2-4152-8cc4-3d864298e572} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 101 (RESET): RESET AUTHENTICATION METHODS TO NEW. Expected one of: VALID UNTIL, token, Comma, HOST, AlterSettingsProfileElements, SETTINGS, SETTING, PROFILES, PROFILE, ADD, DROP, MODIFY, DEFAULT ROLE, GRANTEES, DEFAULT DATABASE, RENAME TO, IN, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48558) (comment: 03174_multiple_authentication_methods.sh) (in query: ALTER USER u01_0317424837 ON CLUSTER test_shard_localhost IDENTIFIED WITH plaintext_password by '1' RESET AUTHENTICATION METHODS TO NEW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:27:40.194346 [ 3885 ] {dc44896c-31f2-4152-8cc4-3d864298e572} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 101 (RESET): RESET AUTHENTICATION METHODS TO NEW. Expected one of: VALID UNTIL, token, Comma, HOST, AlterSettingsProfileElements, SETTINGS, SETTING, PROFILES, PROFILE, ADD, DROP, MODIFY, DEFAULT ROLE, GRANTEES, DEFAULT DATABASE, RENAME TO, IN, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:40.324572 [ 32979 ] {18f2f255-a058-4f67-bf02-f9a5d044af81} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50848) (comment: 00753_distributed_system_columns_and_system_tables.sql) (in query: DROP DATABASE IF EXISTS test_0t7gfh0f SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:27:40.331026 [ 32979 ] {18f2f255-a058-4f67-bf02-f9a5d044af81} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:40.372691 [ 34261 ] {6d8f5e69-73a1-4bd0-9119-a84318c2ee85} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38016) (comment: 02186_range_hashed_dictionary_intersecting_intervals.sql) (query 15, line 40) (in query: DROP DICTIONARY 02186_range_dictionary;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:27:40.445354 [ 34261 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:27:41.041412 [ 33000 ] {40c1ba85-97df-48db-a67e-cf8a65508c84} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 402, line 402) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT as r FORMAT CSV;) 2025.07.13 02:27:41.049683 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:41.853870 [ 33000 ] {4340bd58-26e3-4802-800e-64d14ec7ce20} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 407, line 407) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT - N as r FORMAT CSV;) 2025.07.13 02:27:41.859119 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:41.879253 [ 4529 ] {fc715363-3be4-4e45-a04f-e1937fc499d8} executeQuery: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000238 */ ALTER TABLE test_5.table_with_version (MODIFY COLUMN `version` String)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:41.917761 [ 4529 ] {fc715363-3be4-4e45-a04f-e1937fc499d8} executeQuery: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38012) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 17, line 39) (in query: ALTER TABLE table_with_version MODIFY COLUMN version String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:41.925672 [ 4529 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.247607 [ 4529 ] {98824fe0-3530-4edc-9913-7ef1f40ba351} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000239 */ ALTER TABLE test_5.table_with_version (MODIFY COLUMN `version` Int64)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.295259 [ 4529 ] {98824fe0-3530-4edc-9913-7ef1f40ba351} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38012) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 18, line 40) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Int64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.300029 [ 4529 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.523024 [ 33000 ] {b53f1a2e-fe38-43bc-8252-946f53f4dee9} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 413, line 413) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.07.13 02:27:42.532225 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:42.597389 [ 33000 ] {a32a922b-9abe-46fb-9898-2410a086c908} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 414, line 414) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.07.13 02:27:42.607265 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:42.831586 [ 4529 ] {596fc3c0-f78d-42fc-99d5-fc63d580e6f5} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000240 */ ALTER TABLE test_5.table_with_version (MODIFY COLUMN `version` UInt16)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3493: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7426 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.893903 [ 34268 ] {783d74e6-3b1b-4eb4-beff-8c5f9a1abc16} executeQuery: Code: 16. DB::Exception: Column b does not exist in the materialized view's inner table. (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43156) (comment: 03022_alter_materialized_view_query_has_inner_table.sql) (query 8, line 12) (in query: ALTER TABLE mv MODIFY QUERY SELECT a, b FROM src_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:101: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304e709a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.894677 [ 4529 ] {596fc3c0-f78d-42fc-99d5-fc63d580e6f5} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38012) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 19, line 41) (in query: ALTER TABLE table_with_version MODIFY COLUMN version UInt16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3493: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7426 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.906944 [ 34268 ] {} TCPHandler: Code: 16. DB::Exception: Column b does not exist in the materialized view's inner table. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:101: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000304e709a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:42.907423 [ 4529 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3493: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7426 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.026500 [ 2827 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5656 similar messages) 2025.07.13 02:27:43.152825 [ 33000 ] {5ccd0d96-7b73-4901-9530-5a2083250c73} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 418, line 418) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.07.13 02:27:43.172290 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:43.197934 [ 4529 ] {28e6b989-9084-4e3e-94c9-6cc23abdbaf8} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000241 */ ALTER TABLE test_5.table_with_version (MODIFY COLUMN `version` Float64)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.218186 [ 4529 ] {28e6b989-9084-4e3e-94c9-6cc23abdbaf8} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38012) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 20, line 42) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Float64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.234888 [ 4529 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.269318 [ 5382 ] {2dbe375c-9c82-4007-b987-7b47e494d405} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50946) (comment: 01160_table_dependencies.sh) (in query: DROP DATABASE IF EXISTS test_zk5s8hlx SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.269455 [ 33000 ] {a3bff480-4ea7-4c90-b272-451cf7ba050f} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 419, line 419) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.07.13 02:27:43.273142 [ 5382 ] {2dbe375c-9c82-4007-b987-7b47e494d405} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:43.281214 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:43.560369 [ 4529 ] {8b533b40-535e-4375-9c42-11c57282413f} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000242 */ ALTER TABLE test_5.table_with_version (MODIFY COLUMN `version` Date)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.581770 [ 4529 ] {8b533b40-535e-4375-9c42-11c57282413f} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38012) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 21, line 43) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.588494 [ 4529 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.639676 [ 33000 ] {8ac28514-6dfb-4ce5-912c-300d9830f9bd} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 422, line 422) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT64 as r FORMAT CSV;) 2025.07.13 02:27:43.654990 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:43.817109 [ 4529 ] {b1b3fd0a-187a-469b-b9e2-7407e5e46ad1} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000243 */ ALTER TABLE test_5.table_with_version (MODIFY COLUMN `version` DateTime)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.926041 [ 4529 ] {b1b3fd0a-187a-469b-b9e2-7407e5e46ad1} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38012) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 22, line 44) (in query: ALTER TABLE table_with_version MODIFY COLUMN version DateTime;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:43.928519 [ 4529 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3484: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd7526 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:44.348621 [ 33000 ] {a1af8a06-9b7b-4159-9044-a5037f941c67} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 427, line 427) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT64 - N as r FORMAT CSV;) 2025.07.13 02:27:44.358235 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:27:45.227567 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:45.227839 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:46.271051 [ 34275 ] {2658d3a2-ce3c-44a0-a8b0-59c6bfbf9656} executeQuery: Code: 10. DB::Exception: Not found column key2 in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 91, line 114) (in query: SELECT t1.key FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND 0 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002cb2a0de 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1722: _ZZN2DB12_GLOBAL__N_131buildQueryPlanForJoinNodeLegacyERKNSt3__110shared_ptrINS_14IQueryTreeNodeEEENS_17JoinTreeQueryPlanES7_RKNS1_13unordered_setINS1_12basic_stringIcNS1_11char_traitsIcEENS1_9allocatorIcEEEENS1_4hashISE_EENS1_8equal_toISE_EENSC_ISE_EEEERNS2_INS_14PlannerContextEEERKNS_15SelectQueryInfoEENK3$_1clINS1_6vectorIPKNS_10ActionsDAG4NodeENSC_ISZ_EEEEEEDaRSW_RNS_9QueryPlanERNS8_INS2_INS_9FutureSetEEENSF_IS16_EENSH_IS16_EENSC_IS16_EEEERKT_ @ 0x000000002ddb9793 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1734: 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&) @ 0x000000002ddb54fc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:46.327131 [ 34275 ] {} TCPHandler: Code: 10. DB::Exception: Not found column key2 in block __table1.key String String(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002cb2a0de 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1722: _ZZN2DB12_GLOBAL__N_131buildQueryPlanForJoinNodeLegacyERKNSt3__110shared_ptrINS_14IQueryTreeNodeEEENS_17JoinTreeQueryPlanES7_RKNS1_13unordered_setINS1_12basic_stringIcNS1_11char_traitsIcEENS1_9allocatorIcEEEENS1_4hashISE_EENS1_8equal_toISE_EENSC_ISE_EEEERNS2_INS_14PlannerContextEEERKNS_15SelectQueryInfoEENK3$_1clINS1_6vectorIPKNS_10ActionsDAG4NodeENSC_ISZ_EEEEEEDaRSW_RNS_9QueryPlanERNS8_INS2_INS_9FutureSetEEENSF_IS16_EENSH_IS16_EENSC_IS16_EEEERKT_ @ 0x000000002ddb9793 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1734: 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&) @ 0x000000002ddb54fc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:46.907157 [ 34260 ] {b855af3d-1ced-466e-acc6-d2b943783534} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43448) (comment: 01042_h3_k_ring.sql) (query 3, line 5) (in query: SELECT h3kRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:46.911094 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.007103 [ 34260 ] {cfed3b77-0055-4b98-901e-803f333979ef} executeQuery: Code: 12. DB::Exception: Too large 'k' argument for h3kRing function, maximum 10000: In scope SELECT h3kRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43448) (comment: 01042_h3_k_ring.sql) (query 4, line 6) (in query: SELECT h3kRing(581276613233082367, toUInt16(-1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001c164faf 5. DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c183ab2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:47.025673 [ 34260 ] {} TCPHandler: Code: 12. DB::Exception: Too large 'k' argument for h3kRing function, maximum 10000: In scope SELECT h3kRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001c164faf 5. DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c183ab2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:27:47.073100 [ 34277 ] {c6d13875-3cbb-4690-8d2d-9aa324f13881} executeQuery: Code: 59. DB::Exception: Illegal type UInt32 of column modulo(__table1.n, 143011_UInt32) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43346) (comment: 02513_prewhere_combine_step_filters.sql) (query 12, line 19) (in query: SELECT * FROM table_02513 WHERE n%143011;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc9ff7 6. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003211638f 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd49d49 8. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd841aa 9. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a6ab 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.088525 [ 34277 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt32 of column modulo(__table1.n, 143011_UInt32) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc9ff7 6. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003211638f 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd49d49 8. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd841aa 9. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a6ab 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.332665 [ 34260 ] {86261648-cabc-4fd1-ab6c-21c22154d3ed} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43448) (comment: 01042_h3_k_ring.sql) (query 7, line 10) (in query: SELECT h3kRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.336950 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.414642 [ 34277 ] {6c7ed20a-4314-4271-8b54-2f795d019aac} executeQuery: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43346) (comment: 02513_prewhere_combine_step_filters.sql) (query 13, line 20) (in query: SELECT * FROM table_02513 PREWHERE n%143011;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000030230324 6. ./src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000030f54bd9 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f52465 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:102: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fd1d 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 11. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.418536 [ 34277 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000030230324 6. ./src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000030f54bd9 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f52465 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:102: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fd1d 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 11. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.692392 [ 34277 ] {98c452c2-aa84-49f5-838d-456b4766bac8} executeQuery: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43346) (comment: 02513_prewhere_combine_step_filters.sql) (query 15, line 22) (in query: SELECT * FROM table_02513 PREWHERE n%143011 WHERE n%13;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000030230324 6. ./src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000030f54bd9 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f52465 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:102: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fd1d 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 11. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.698733 [ 34277 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt32 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000030230324 6. ./src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000030f54bd9 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f52465 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:102: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7fd1d 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 11. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:27:47.978382 [ 34260 ] {78a336eb-b9af-4548-9a2f-686157b284c5} executeQuery: Code: 57. DB::Exception: Table test_5.h3_indexes already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01042_h3_k_ring.sql) (in query: /* ddl_entry=query-0000000246 */ CREATE TABLE test_5.h3_indexes UUID '095aad42-1ee2-4f53-8463-11ec5c522545' (`h3_index` UInt64, `k` UInt16) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:48.008692 [ 34260 ] {78a336eb-b9af-4548-9a2f-686157b284c5} executeQuery: Code: 57. DB::Exception: Table test_5.h3_indexes already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43448) (comment: 01042_h3_k_ring.sql) (query 9, line 14) (in query: -- Test h3 indices and k selected from original test fixture: https://github.com/uber/h3/blob/master/src/apps/testapps CREATE TABLE h3_indexes (h3_index UInt64, k UInt16) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:48.016451 [ 34260 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.h3_indexes already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:48.656032 [ 34273 ] {0ccc9693-cd43-4646-8d23-310819618f85} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43518) (comment: 01493_alter_remove_wrong_default.sql) (query 3, line 11) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:48.667380 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:48.779080 [ 34273 ] {556f3be9-db40-4f56-b94c-3aac888c6ad3} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43518) (comment: 01493_alter_remove_wrong_default.sql) (query 4, line 12) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:48.789377 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.012390 [ 34273 ] {cc6dca96-af12-4e17-a7e5-7acebe0a8357} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43518) (comment: 01493_alter_remove_wrong_default.sql) (query 5, line 14) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.027332 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.158718 [ 34273 ] {6ac552d1-9303-4444-9584-433fa6c72343} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43518) (comment: 01493_alter_remove_wrong_default.sql) (query 6, line 15) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.163489 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7fa6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.217002 [ 34273 ] {aa01c9fe-f4a7-4507-b202-2359ef3bc307} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43518) (comment: 01493_alter_remove_wrong_default.sql) (query 7, line 17) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.230703 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7dc6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.363811 [ 34273 ] {0778d5f3-8896-4fe3-8d21-06955ae6dbfd} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43518) (comment: 01493_alter_remove_wrong_default.sql) (query 8, line 18) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.370273 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7eb4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:49.785029 [ 34272 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:50.312040 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:50.392293 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:52.936502 [ 5476 ] {32020c36-293d-40ef-bdd2-d757c1cb8c89} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56498) (comment: 02125_lz4_compression_bug_JSONStringsEachRow.sh) (query 1, line 1) (in query: TRUNCATE TABLE file), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:52.963496 [ 5105 ] {0beb10f1-8597-4ce3-98f3-ae1dfd77dd21} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01925_merge_prewhere_table.sql) (in query: /* ddl_entry=query-0000000252 */ TRUNCATE TABLE test_5.x), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:27:52.963759 [ 5476 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.071855 [ 5105 ] {0beb10f1-8597-4ce3-98f3-ae1dfd77dd21} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43540) (comment: 01925_merge_prewhere_table.sql) (query 10, line 13) (in query: DROP TABLE x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.099550 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.143629 [ 34275 ] {45501147-23c3-4651-8ec4-5476cb8c5256} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 115, line 143) (in query: -- `e + 1` is UInt16, but `t1.id == t2.id AND e + 1` is UInt8 SELECT DISTINCT t1.key, toUInt8(t1.id) as e FROM t1 INNER ANY JOIN t2 ON t1.id == t2.id AND e + 1 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.166357 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(toUInt8(__table1.id), 1_UInt8)' of type 'UInt16'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.924752 [ 3816 ] {56b6bb56-1cf2-4753-b0c1-740e1ab66b36} 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.3.20372.altinityantalya (altinity build)) (from [::1]:56598) (comment: 02485_zero_copy_commit_error.sql) (query 1, line 3) (in query: CREATE TABLE rmt1 (`n` int, `m` int, `k` int) ENGINE = ReplicatedMergeTree('/test/02485/{database}/rmt', '1') ORDER BY n SETTINGS storage_policy = 's3_cache', allow_remote_fs_zero_copy_replication = 1, old_parts_lifetime = 60, cleanup_delay_period = 60, max_cleanup_delay_period = 60, cleanup_delay_period_random_add = 1, min_bytes_for_wide_part = 0, simultaneous_parts_removal_limit = 1, index_granularity = 55613, 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 = 357481129, compact_parts_max_granules_to_buffer = 17, compact_parts_merge_max_bytes_to_prefetch_part = 13514335, merge_max_block_size = 4449, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 85, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 9507130, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 15, 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 = 58263, primary_key_compress_block_size = 16354, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.957384 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:27:53.960471 [ 10341 ] {ce473503-2f4a-4cc1-a799-4256c7717ac2} executeQuery: Code: 57. DB::Exception: Table test_of5z3kjt.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56602) (comment: 02941_variant_type_3.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 106524961, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 21431025, merge_max_block_size = 8689, old_parts_lifetime = 239., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 439613, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 87574, primary_key_compress_block_size = 40391, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:54.092110 [ 10341 ] {} TCPHandler: Code: 57. DB::Exception: Table test_of5z3kjt.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:27:54.122919 [ 34272 ] {006d95f4-d07b-4efa-9a40-3fa957ed96f7} executeQuery: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000253 */ CREATE TABLE test_5.replacing_wrong UUID '6b767977-c33f-4d83-bda8-9dd0459389e7' (`key` Int64, `ver` Int64, `is_deleted` UInt16) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7dbaa 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:27:54.239751 [ 34272 ] {006d95f4-d07b-4efa-9a40-3fa957ed96f7} executeQuery: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 1, line 1) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt16) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7dbaa 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:27:54.245338 [ 34272 ] {} TCPHandler: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7dbaa 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:27:54.783065 [ 34272 ] {acedc64e-a7bd-4f44-9818-d71dfceb6b57} executeQuery: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000254 */ CREATE TABLE test_5.replacing_wrong UUID '47db5c9a-cc27-4fb7-8894-96f2945511e7' (`key` Int64, `ver` String, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c898a7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d2eb 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:27:54.891791 [ 34275 ] {eb021412-96b8-4bc2-91e4-d94e4da382b5} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 121, line 152) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:54.956204 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:54.974153 [ 34272 ] {acedc64e-a7bd-4f44-9818-d71dfceb6b57} executeQuery: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 2, line 2) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` String, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c898a7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d2eb 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:27:54.979296 [ 34272 ] {} TCPHandler: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c898a7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d2eb 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:27:55.070925 [ 34275 ] {58c84200-88f0-434b-9019-481b53e2e21f} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 122, line 153) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:55.090828 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table2.id' of type 'Int32'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:55.204733 [ 34275 ] {483ca2e9-7497-4b24-a363-2708b6028476} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 123, line 154) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.id + 2 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:55.220893 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table1.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000002de56335 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:27:55.346787 [ 34275 ] {abaf798a-25f5-48ab-a94a-16b6b2c2f508} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 124, line 155) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.id + 2 SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:55.356761 [ 34275 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column 'plus(__table2.id, 2_UInt8)' of type 'Int64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x000000002de56688 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e465b31 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dced1e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x00000000321357dc 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x00000000321321ea 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002dddc38b 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: 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&) @ 0x000000002ddbac8d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:55.381061 [ 34272 ] {3fe9cab0-9b2c-4b60-bf70-46842fb893b8} executeQuery: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000255 */ CREATE TABLE test_5.replacing_wrong UUID '7cbee462-2f42-4610-9c85-5ed3ccdada2a' (`key` Int64, `ver` Int64, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(is_deleted, is_deleted) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d529 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:27:55.420227 [ 34272 ] {3fe9cab0-9b2c-4b60-bf70-46842fb893b8} executeQuery: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 3, line 3) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(is_deleted, is_deleted) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d529 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:27:55.428418 [ 34272 ] {} TCPHandler: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d529 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:27:55.515532 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:55.522338 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:56.239012 [ 34272 ] {57c78043-5038-40ca-82db-d828dd2f2324} executeQuery: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000257 */ ALTER TABLE test_5.replacing (MODIFY COLUMN `ver` String)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:56.279996 [ 34272 ] {57c78043-5038-40ca-82db-d828dd2f2324} executeQuery: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 5, line 6) (in query: ALTER TABLE replacing MODIFY COLUMN ver String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:56.285791 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6a50 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:56.702543 [ 34275 ] {3da652b3-5941-42fc-8de6-ae2a2e17ab77} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 129, line 162) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t1.key;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:56.706463 [ 34275 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t1.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:56.786826 [ 34275 ] {56c2c57a-9201-4d33-8faa-72d75a1c7c8c} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01881_join_on_conditions_hash.gen.sql) (query 130, line 163) (in query: SELECT * FROM t1 INNER ALL JOIN t2 ON t1.id == t2.id AND t2.key;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:56.805797 [ 34275 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 ALL INNER JOIN t2 ON (t1.id = t2.id) AND t2.key. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002ad4ecc4 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc60a6d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.151130 [ 34272 ] {50eb0b72-5671-45a0-ad71-0d90bdf3a2ce} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000259 */ ALTER TABLE test_5.replacing (MODIFY COLUMN `is_deleted` String)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.182623 [ 34272 ] {50eb0b72-5671-45a0-ad71-0d90bdf3a2ce} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 7, line 8) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.186590 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.465458 [ 34272 ] {c6630edf-f786-4f69-b111-6440a7bd497a} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000260 */ ALTER TABLE test_5.replacing (MODIFY COLUMN `is_deleted` UInt16)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.554409 [ 34272 ] {c6630edf-f786-4f69-b111-6440a7bd497a} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 8, line 9) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted UInt16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.572811 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:57.912356 [ 34272 ] {0da668ba-46ab-490b-9a72-0d9dee9146a8} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000261 */ ALTER TABLE test_5.replacing (MODIFY COLUMN `is_deleted` Int8)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:58.010359 [ 34272 ] {0da668ba-46ab-490b-9a72-0d9dee9146a8} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 9, line 10) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted Int8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:58.062260 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:58.497843 [ 34272 ] {d884d771-6117-4895-bab4-61cacd0d5e9c} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000262 */ ALTER TABLE test_5.replacing (DROP COLUMN ver)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:58.523261 [ 34272 ] {d884d771-6117-4895-bab4-61cacd0d5e9c} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 10, line 11) (in query: ALTER TABLE replacing DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:58.528325 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.017050 [ 34272 ] {014d4fb7-bbc4-49b3-94b2-5fd23dd64231} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000263 */ ALTER TABLE test_5.replacing (DROP COLUMN is_deleted)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.085503 [ 34272 ] {014d4fb7-bbc4-49b3-94b2-5fd23dd64231} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 11, line 12) (in query: ALTER TABLE replacing DROP COLUMN is_deleted;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.088092 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.359710 [ 34272 ] {05803cb4-7500-4ff2-833b-695bdeead1fc} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000264 */ ALTER TABLE test_5.replacing (RENAME COLUMN ver TO ver2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.450312 [ 34272 ] {05803cb4-7500-4ff2-833b-695bdeead1fc} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 12, line 13) (in query: ALTER TABLE replacing RENAME COLUMN ver TO ver2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.454128 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:27:59.974752 [ 34272 ] {09d650fc-b56c-4cff-be32-4a3c2a073f8f} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000265 */ ALTER TABLE test_5.replacing (RENAME COLUMN is_deleted TO is_deleted2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:00.022776 [ 34272 ] {09d650fc-b56c-4cff-be32-4a3c2a073f8f} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 13, line 14) (in query: ALTER TABLE replacing RENAME COLUMN is_deleted TO is_deleted2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:00.025890 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:00.436536 [ 34272 ] {6be4d944-85f2-4ff1-9614-22d2a7cd637f} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000266 */ CREATE TABLE test_5.collapsing_wrong UUID '1ca5a573-4846-4f2b-82da-8de3cc01f7aa' (`key` Int64, `sign` Int16) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:00.528032 [ 34272 ] {6be4d944-85f2-4ff1-9614-22d2a7cd637f} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 14, line 16) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` Int16) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:00.532733 [ 34272 ] {} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:00.750915 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:00.757090 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:00.854093 [ 34272 ] {a3efcb07-dc0d-40b2-833b-07bea968135f} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000267 */ CREATE TABLE test_5.collapsing_wrong UUID '3898e67e-2848-437e-8944-97d072783687' (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:00.960643 [ 34272 ] {a3efcb07-dc0d-40b2-833b-07bea968135f} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 15, line 17) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:00.963759 [ 34272 ] {} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c80384f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c89568 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:01.155179 [ 3816 ] {b839fa65-a1f1-4060-a2b5-f21aa3ccd475} executeQuery: Code: 48. DB::Exception: Method optimize is not supported by storage Memory. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39192) (comment: 02941_variant_type_3.sh) (query 1, line 1) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003031edf7 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:28:01.167255 [ 3816 ] {} TCPHandler: Code: 48. DB::Exception: Method optimize is not supported by storage Memory. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003031edf7 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e331557 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:28:01.360971 [ 34272 ] {6a7fdf86-9017-474e-8797-69b826e9b77f} executeQuery: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000268 */ CREATE TABLE test_5.collapsing_wrong UUID '1bab133e-1bcb-4a2a-a07f-38e198b5cce6' (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(not_existing) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c8944e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:01.383803 [ 34272 ] {6a7fdf86-9017-474e-8797-69b826e9b77f} executeQuery: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 16, line 18) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(not_existing) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c8944e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:01.393713 [ 34272 ] {} TCPHandler: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c8944e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7cd21 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:28:02.068609 [ 34272 ] {f565ec26-7d14-413b-bef1-7249a9858142} executeQuery: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000270 */ ALTER TABLE test_5.collapsing (MODIFY COLUMN `sign` String)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.119315 [ 34272 ] {f565ec26-7d14-413b-bef1-7249a9858142} executeQuery: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 18, line 21) (in query: ALTER TABLE collapsing MODIFY COLUMN sign String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.122264 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d979ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdded6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.336727 [ 34272 ] {7345be33-db09-4cbe-89d6-c81dbbe64f2e} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000271 */ ALTER TABLE test_5.collapsing (DROP COLUMN sign)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.380483 [ 34272 ] {7345be33-db09-4cbe-89d6-c81dbbe64f2e} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 19, line 22) (in query: ALTER TABLE collapsing DROP COLUMN sign;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.390412 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddf46 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.650412 [ 34272 ] {1b949196-d634-47f6-9f18-3cb91a3ae9c7} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000272 */ ALTER TABLE test_5.collapsing (RENAME COLUMN sign TO sign2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.760977 [ 34272 ] {1b949196-d634-47f6-9f18-3cb91a3ae9c7} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 20, line 23) (in query: ALTER TABLE collapsing RENAME COLUMN sign TO sign2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:02.767073 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d97a6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cddfb6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:03.005669 [ 34272 ] {f2550852-c114-4837-abcf-086d5d4dfdab} executeQuery: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000273 */ ALTER TABLE test_5.collapsing (MODIFY COLUMN `sign` MODIFY SETTING max_compress_block_size = 123456)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d9796f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdddca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:03.056168 [ 34272 ] {f2550852-c114-4837-abcf-086d5d4dfdab} executeQuery: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 21, line 24) (in query: ALTER TABLE collapsing MODIFY COLUMN sign MODIFY SETTING max_compress_block_size = 123456;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d9796f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdddca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:03.111018 [ 34272 ] {} TCPHandler: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d9796f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cdddca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd3422 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:03.499074 [ 34272 ] {a5c40c08-8cdf-49ff-94f6-fef7e5b48976} executeQuery: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03093_special_column_errors.sql) (in query: /* ddl_entry=query-0000000274 */ CREATE TABLE test_5.versioned_collapsing_wrong UUID '7af27873-1c83-4f75-9313-a7de709fe598' (`key` Int64, `version` UInt8, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(sign, sign) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d5c4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:28:03.552925 [ 34272 ] {a5c40c08-8cdf-49ff-94f6-fef7e5b48976} executeQuery: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56576) (comment: 03093_special_column_errors.sql) (query 22, line 26) (in query: CREATE TABLE versioned_collapsing_wrong (`key` Int64, `version` UInt8, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(sign, sign) ORDER BY key SETTINGS index_granularity = 25410, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.38808712363243103, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535696763, compact_parts_max_bytes_to_buffer = 361434105, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 27377095, merge_max_block_size = 564, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 764406, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7592791347, index_granularity_bytes = 12527296, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 16, 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 = 73359, primary_key_compress_block_size = 77130, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d5c4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:28:03.570256 [ 34272 ] {} TCPHandler: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7d5c4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: 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) @ 0x0000000030c7a986 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:28:04.372366 [ 34261 ] {9968ed19-8b3e-45ff-96dc-736140bdeb4b} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:37786): While executing JSONRowOutputFormat. (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37786) (comment: 03280_cancelation_http_when_outputformat.sh) (in query: SELECT toDate('2020-12-12') as datetime, 'test-pipeline' as pipeline, 'clickhouse-test-host-001.clickhouse.com' as host, 'clickhouse' as home, 'clickhouse' as detail, number as row_number FROM numbers(1000000) SETTINGS max_block_size=65505 FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:105: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000023caf5b7 5. ./src/Server/HTTP/HTTPServerResponse.h:196: DB::HTTPWriteBuffer::nextImplChunked() @ 0x00000000317068b0 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:145: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003170145e 7. DB::WriteBuffer::next() @ 0x0000000017cd6383 8. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:115: DB::IOutputFormat::work() @ 0x000000003184b856 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:28:04.375587 [ 34261 ] {9968ed19-8b3e-45ff-96dc-736140bdeb4b} DynamicQueryHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:37786): While executing JSONRowOutputFormat. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:105: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000023caf5b7 5. ./src/Server/HTTP/HTTPServerResponse.h:196: DB::HTTPWriteBuffer::nextImplChunked() @ 0x00000000317068b0 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:145: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003170145e 7. DB::WriteBuffer::next() @ 0x0000000017cd6383 8. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:115: DB::IOutputFormat::work() @ 0x000000003184b856 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:04.405039 [ 34261 ] {9968ed19-8b3e-45ff-96dc-736140bdeb4b} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 236. DB::Exception: Write buffer has been canceled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:248: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x0000000031704893 6. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000315c3822 7. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c7c3e 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:05.550784 [ 2975 ] {} test_3.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.557692 [ 2944 ] {} test_1.t1_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.566484 [ 2980 ] {} test_3.deduplication (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.582866 [ 2954 ] {} test_1.t1_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.588304 [ 2951 ] {} test_1.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.590601 [ 2959 ] {} test_1.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.593740 [ 2969 ] {} test_11.table_rename_with_ttl (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.595876 [ 2983 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.600896 [ 2920 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:28:05.619164 [ 2982 ] {} test_az2mbsvi.r1 (6273f516-e6ed-4a3a-b6d4-a52cf66a829b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:05.620049 [ 2981 ] {} test_az2mbsvi.r2 (a0bab243-fe99-449f-93d0-f638a4262f19): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:05.623807 [ 2931 ] {} rdb_test_11.rmt (8d010f9c-e8eb-434f-afc0-939bc9fa4c09): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:05.720305 [ 2825 ] {0e17a3b7-9983-4295-b08f-3789b92f28b6} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46980) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.rmt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1479: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003282976b 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1290: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x00000000327627de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:561: zkutil::ZooKeeper::existsImpl(String const&, Coordination::Stat*, std::function) @ 0x00000000327622b7 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:595: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000032762a76 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003275fad8 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:700: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x000000003059eee4 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7981: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000030691b07 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7954: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c538a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37d8df 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:05.750667 [ 2825 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1479: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003282976b 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1290: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x00000000327627de 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:561: zkutil::ZooKeeper::existsImpl(String const&, Coordination::Stat*, std::function) @ 0x00000000327622b7 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:595: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000032762a76 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003275fad8 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:700: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x000000003059eee4 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7981: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000030691b07 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7954: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c538a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 16. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37d8df 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:05.945434 [ 29256 ] {31af7320-dcec-49fa-ac4a-05ade37535fc} executeQuery: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39322) (comment: 02461_mullable_pk_monotonicity_bug.sql) (query 1, line 1) (in query: CREATE TABLE tab (`x` Nullable(UInt8)) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 2, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 76, min_bytes_for_full_part_storage = 405103611, compact_parts_max_bytes_to_buffer = 201120322, compact_parts_max_granules_to_buffer = 115, compact_parts_merge_max_bytes_to_prefetch_part = 14261467, merge_max_block_size = 7521, old_parts_lifetime = 243., 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 = 5110063052, index_granularity_bytes = 4566714, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 93, 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 = 14641, primary_key_compress_block_size = 76166, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003117f00d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003117ef02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1781: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x0000000032824d40 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1294: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032823e32 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275e8cc 12. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:322: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275e7da 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1140: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c783980 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:05.968677 [ 29256 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003117f00d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003117ef02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1781: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x0000000032824d40 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1294: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032823e32 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275e8cc 12. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:322: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275e7da 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1140: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c783980 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.180308 [ 34277 ] {7d2cdda1-aff9-49c8-b204-a873fc58036e} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39366) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.201742 [ 34277 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.260313 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:06.260847 [ 4450 ] {} DDLWorker(rdb_test_11_3): Error on initialization of rdb_test_11_3: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:06.414312 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.416116 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.527464 [ 5072 ] {cc36101d-779f-481a-9236-8ccc733753ee} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:38264 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39360) (comment: 00295_global_in_one_shard_rows_before_limit.sql) (query 2, line 4) (in query: SELECT arrayJoin(range(100)) AS x FROM remote('127.0.0.2', system.one) WHERE x GLOBAL IN (SELECT toUInt8(arrayJoin(range(100)) + 50)) GROUP BY x ORDER BY x LIMIT 10 FORMAT JSONCompact;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148f8bf 7. ./build_docker/./src/Client/Connection.cpp:1174: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x00000000314939cd 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314d3c5d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314d361e 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3c42f5 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3c207d 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:28:06.595469 [ 5072 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:38264 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148f8bf 7. ./build_docker/./src/Client/Connection.cpp:1174: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x00000000314939cd 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314d3c5d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314d361e 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3c42f5 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3c207d 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f95bf 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.797911 [ 29256 ] {fb800ce1-f455-46c7-a7b7-9866e34b71a1} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39396) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7905: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c37c6 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.823276 [ 34268 ] {8534b5ff-ca7f-4a57-8d5b-8bdd64d16ac1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57240) (comment: 02461_mullable_pk_monotonicity_bug.sql) (in query: DROP DATABASE IF EXISTS test_rnocig6d SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:06.829109 [ 34268 ] {8534b5ff-ca7f-4a57-8d5b-8bdd64d16ac1} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:06.850695 [ 29256 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7905: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c37c6 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:28:08.453109 [ 34268 ] {9535b2e7-f6de-4be4-9cfc-f25628d13be1} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37800) (comment: 00336_shard_stack_trace.sh) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:28:08.456880 [ 34268 ] {9535b2e7-f6de-4be4-9cfc-f25628d13be1} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:08.637994 [ 5072 ] {766da378-5fcb-4e27-9319-62426b66dfe8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37806) (comment: 00336_shard_stack_trace.sh) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:28:08.648174 [ 5072 ] {766da378-5fcb-4e27-9319-62426b66dfe8} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:08.697030 [ 34268 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:08.746287 [ 34277 ] {99bfb151-deb5-4d7f-ae5c-33d32c25f654} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49216) (comment: 00336_shard_stack_trace.sh) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:28:08.748297 [ 34277 ] {99bfb151-deb5-4d7f-ae5c-33d32c25f654} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:08.950044 [ 3458 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d8b624c5-d643-4a2a-aaf9-5c25097d34b6::202507_86_106_4}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:09.300724 [ 34277 ] {d5d0fe5a-d64c-49d2-b652-fef5d18efe03} executeQuery: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49226) (comment: 00336_shard_stack_trace.sh) (in query: SELECT intDiv(number, 0) FROM remote('127.0.0.{2,3}', system.numbers)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000001c20430e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c60bb10 7. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001c60b36a 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001c60a0bc 9. 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&&) @ 0x000000001c5c5c0c 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c5c0f23 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bee8c 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bd288 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 23. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 24. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:28:09.315431 [ 34277 ] {d5d0fe5a-d64c-49d2-b652-fef5d18efe03} DynamicQueryHandler: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000001c20430e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c60bb10 7. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001c60b36a 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001c60a0bc 9. 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&&) @ 0x000000001c5c5c0c 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c5c0f23 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bee8c 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bd288 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 23. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 24. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:09.678873 [ 2824 ] {bf320928-4101-48af-b5ea-e638794bedd9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48234) (comment: 00336_shard_stack_trace.sh) (query 1, line 1) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:09.706094 [ 2824 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:09.892694 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:10.288498 [ 3766 ] {8b47db61-21cd-4d69-8c6d-cb8d03389ee0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48252) (comment: 00336_shard_stack_trace.sh) (query 1, line 1) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:10.300997 [ 3766 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:11.029409 [ 5476 ] {d19a85fc-92b4-4d6b-bd3c-64a42f47d13f} executeQuery: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48284) (comment: 00336_shard_stack_trace.sh) (query 1, line 1) (in query: SELECT intDiv(number, 0) FROM remote('127.0.0.{2,3}', system.numbers)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000001c20430e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c60bb10 7. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001c60b36a 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001c60a0bc 9. 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&&) @ 0x000000001c5c5c0c 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c5c0f23 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bee8c 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bd288 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 23. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 24. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:28:11.073386 [ 5476 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000001c20430e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c60bb10 7. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001c60b36a 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001c60a0bc 9. 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&&) @ 0x000000001c5c5c0c 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001c5c0f23 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bee8c 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5bd288 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 23. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 24. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Planner/Planner.cpp:245: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002dd72762 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d0f6 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:28:11.333408 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:11.692549 [ 5476 ] {01ea1ca8-57f0-45e8-828a-d06c162e1b33} executeQuery: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48324) (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 = 1., replace_long_file_name_to_hash = false, max_file_name_length = 81, min_bytes_for_full_part_storage = 273588233, compact_parts_max_bytes_to_buffer = 403392751, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 7930742, merge_max_block_size = 11895, old_parts_lifetime = 183., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9986242, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, 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 = false, marks_compress_block_size = 31078, primary_key_compress_block_size = 63627, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Parsers/ASTIdentifier.cpp:270: DB::getIdentifierName(DB::IAST const*) @ 0x0000000032eb296a 6. ./src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c4081 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:11.697653 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Parsers/ASTIdentifier.cpp:270: DB::getIdentifierName(DB::IAST const*) @ 0x0000000032eb296a 6. ./src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c4081 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:11.719297 [ 5105 ] {8f32fb2c-142e-4571-8761-9d1f37727118} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48334) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:11.728521 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:12.228714 [ 5105 ] {cf940be5-6e5a-4876-9df0-3c2202ebe642} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48350) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:12.242743 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b5d0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:12.632786 [ 5105 ] {1f9325f5-c546-4e51-8cff-d15612ea2910} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48370) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:12.655020 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:13.103972 [ 5105 ] {7520d1f1-55a4-48bb-916a-1b23c34a4f2e} 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.3.20372.altinityantalya (altinity build)) (from [::1]:48380) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:28:13.204423 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4e292 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:28:13.222500 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:13.233105 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:28:13.553641 [ 34272 ] {f557f74a-29ca-461a-b975-42c34173022b} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48400) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.mt update n=2 where n=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:13.575813 [ 34272 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7a3966 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c7a30c7 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4b48f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:14.129066 [ 34273 ] {c5920ab1-ea7a-4e6c-9460-423c9e7104f1} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48406) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt update n=2 where n=1 settings mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7905: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c37c6 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:28:14.160040 [ 34273 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7905: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c37c6 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:28:14.669410 [ 34272 ] {b2ff73c4-c3f1-4b4a-b9b6-967d6b6032dd} executeQuery: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01925_jit_aggregation_function_count_long.sql) (in query: /* ddl_entry=query-0000000276 */ CREATE TABLE test_5.test_table UUID '792fcc83-a2ce-4f39-98c5-8a198feb396a' (`id` UInt64, `value` UInt8, `value_nullable` Nullable(UInt8)) ENGINE = TinyLog), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:14.729026 [ 34272 ] {b2ff73c4-c3f1-4b4a-b9b6-967d6b6032dd} executeQuery: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48420) (comment: 01925_jit_aggregation_function_count_long.sql) (query 4, line 7) (in query: CREATE TABLE test_table ( id UInt64, value UInt8, value_nullable Nullable(UInt8) ) ENGINE=TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:14.742477 [ 34272 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.316189 [ 34272 ] {f2950708-9d53-4144-9226-fe9bf61852f1} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48482) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:66: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37c19f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.330015 [ 5105 ] {963af54b-be45-4c54-b5e4-5c0234465f25} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48388) (comment: 01409_topK_merge.sql) (query 7, line 12) (in query: select length(topK(20)((number, ''))) from remote('127.{1,1}', currentDatabase(), data_01409);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.330911 [ 34272 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:66: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37c19f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.347509 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.857667 [ 34272 ] {300fad64-527d-480d-b8b1-3e6ae42dcf6f} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48498) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.rmt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7905: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c37c6 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37d8df 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.864568 [ 5476 ] {1dacb5a8-f311-4d37-b119-b4a79d28a7bd} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: '123456789123451'e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48424) (comment: 01327_decimal_cut_extra_digits_after_point.sql) (query 11, line 13) (in query: -- But it's just Decimal64, so there is the limit. SELECT CAST('12345678912345.1' AS Decimal(10, 5));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c33b5 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c568d7b 7. COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002af0db10 8. 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 @ 0x000000002aef6cfc 9. 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 @ 0x000000002aef2b5e 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::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) @ 0x000000002aef29f4 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:28:15.885777 [ 34272 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000328265eb 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000327634ed 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032762f36 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000032763d13 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000032763984 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003276385f 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7905: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306c37c6 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 15. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37d8df 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:28:15.888271 [ 5476 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: '123456789123451'e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c33b5 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c568d7b 7. COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002af0db10 8. 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 @ 0x000000002aef6cfc 9. 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 @ 0x000000002aef2b5e 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::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) @ 0x000000002aef29f4 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:28:16.797818 [ 5825 ] {} DDLWorker(rdb_test_11_2): Error on initialization of rdb_test_11_2: Code: 57. DB::Exception: Directory for table data store/8d0/8d010f9c-e8eb-434f-afc0-939bc9fa4c09/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c460 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c79503d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c78c8c3 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7b911d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7b53a3 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5bf4bb 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5eac93 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5bed0e 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], 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&) @ 0x000000002c7a4a6f 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e884b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e860f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e82cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e80fc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8190b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5b5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc60594 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:17.092600 [ 10341 ] {e85b2de0-bc84-4d7a-acba-0d7fc9da353d} executeQuery: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48544) (comment: 01679_incorrect_data_on_insert_collapsing.sh) (query 1, line 1) (in query: INSERT INTO collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x0000000031f9068a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000030e4a03b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4c286 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 18. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 19. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:17.112914 [ 10341 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x0000000031f9068a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000030e4a03b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4c286 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 18. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 19. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:28:17.115985 [ 34275 ] {9094e9bf-9882-4bed-b170-14d135983fc8} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48556) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_11.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:66: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37c19f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:28:17.132371 [ 34275 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:66: DB::InterpreterDeleteQuery::execute() @ 0x000000002e37c19f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:28:17.515450 [ 34275 ] {dc5a5ad3-8cdb-4438-838e-a8d3f7f5ccad} executeQuery: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48602) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_11.rmt attach partition id 'all' from rdb_test_11.mt), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5742: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e771 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:17.559628 [ 34275 ] {} TCPHandler: Code: 60. DB::Exception: Table rdb_test_11.mt does not exist. Maybe you meant test_11.ms?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5742: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e771 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:19.529894 [ 33000 ] {81ff8c60-cc95-401b-ad1a-c985d51e9ae8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=853). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 671, line 671) (in query: SELECT 'SELECT N + toUInt64(1)';) 2025.07.13 02:28:19.534937 [ 33000 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=853). (CANNOT_SCHEDULE_TASK) 2025.07.13 02:28:19.795013 [ 34261 ] {ed577da4-c8ea-4ed1-b3dd-c22ce9ddc19d} executeQuery: Code: 36. DB::Exception: Using storage_file_read_method=mmap is not safe in server mode. Consider using pread.: While executing File. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58214) (comment: 02497_storage_file_reader_selection.sh) (query 1, line 1) (in query: SELECT * FROM file('/dev/null', 'LineAsString') FORMAT Null -- { serverError BAD_ARGUMENTS }), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageFile.cpp:285: DB::(anonymous namespace)::createReadBuffer(String const&, stat const&, bool, int, String const&, std::shared_ptr) @ 0x00000000303dc136 6. ./build_docker/./src/Storages/StorageFile.cpp:1429: DB::StorageFileSource::generate() @ 0x00000000303eae47 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:28:19.800614 [ 34261 ] {} TCPHandler: Code: 36. DB::Exception: Using storage_file_read_method=mmap is not safe in server mode. Consider using pread.: While executing File. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageFile.cpp:285: DB::(anonymous namespace)::createReadBuffer(String const&, stat const&, bool, int, String const&, std::shared_ptr) @ 0x00000000303dc136 6. ./build_docker/./src/Storages/StorageFile.cpp:1429: DB::StorageFileSource::generate() @ 0x00000000303eae47 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:22.110624 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:23.329818 [ 33000 ] {d00ddcb9-2aaa-4cb0-849c-fe7bbd50c644} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 697, line 697) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.07.13 02:28:23.364509 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:23.406390 [ 33000 ] {a63299c0-f826-4eb3-9fd1-729dd631ee1a} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 698, line 698) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.07.13 02:28:23.412498 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:23.488428 [ 33000 ] {3abc8015-846c-43ce-944e-6fad7137be55} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 699, line 699) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.07.13 02:28:23.495381 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:24.223443 [ 33000 ] {ca09d9dd-0f98-4bad-84b3-e6dd4e3ef3d2} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 707, line 707) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:24.238513 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:24.315693 [ 33000 ] {f5304766-ea60-4476-8f7a-54642a8ea8a0} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 708, line 708) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:24.323935 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:24.359290 [ 33000 ] {db369baf-0dbb-47f6-af90-925fa0c07750} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 709, line 709) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:24.366136 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:25.615106 [ 33000 ] {962d1520-8c6c-4e5b-888e-c652b18a2a5d} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 717, line 717) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.07.13 02:28:25.618714 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:25.721856 [ 33000 ] {42d67319-215b-45e5-9193-812f8ff941ac} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 718, line 718) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.07.13 02:28:25.725920 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:25.753396 [ 33000 ] {f5b61bb5-1ac7-4235-8f83-b76ee70402a6} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 719, line 719) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.07.13 02:28:25.761559 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:26.998924 [ 33000 ] {b0d62d22-065e-416f-8b6f-4743dfaee1c2} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 727, line 727) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:27.016968 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:27.137820 [ 33000 ] {247e2e64-f41d-43e7-b74b-9e6e155c8988} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 728, line 728) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:27.182808 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:27.269836 [ 33000 ] {c2f4fa75-7b9d-45af-89f5-9fdfdd763f24} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 729, line 729) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:27.276096 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:28.344558 [ 3816 ] {08de05c2-bea1-4925-9268-2e0e36279b35} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58400) (comment: 00097_long_storage_buffer_race_condition.sh) (query 6, line 3) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:28:28.362696 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:28:28.460530 [ 33000 ] {b60326e6-731b-4d43-a2ac-e1d9c8af8bf7} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 737, line 737) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.07.13 02:28:28.467376 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:28.570820 [ 33000 ] {b20c725f-35d0-4bd1-b676-7204e233cf10} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 738, line 738) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.07.13 02:28:28.577750 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:28.673533 [ 33000 ] {3119f6e4-38b3-4369-94ce-e6e8cb5fad41} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 739, line 739) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.07.13 02:28:28.673928 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:28.690751 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:29.752199 [ 5072 ] {b222f59f-e039-4b9b-b24d-82b17c3e23b5} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40850) (comment: 02388_analyzer_recursive_lambda.sql) (query 2, line 3) (in query: WITH x -> plus(lambda(1), x) AS lambda SELECT lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:29.855240 [ 5072 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:29.951577 [ 5072 ] {26f6184a-d0aa-4fdc-ae1b-b9be4be47723} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40850) (comment: 02388_analyzer_recursive_lambda.sql) (query 3, line 5) (in query: WITH lambda(lambda(plus(x, x, -1)), tuple(x), x + 2147483646) AS lambda, x -> plus(lambda(1), x, 2) AS lambda SELECT 1048576, lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:29.954409 [ 5072 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4df4a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4d8b9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38633 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:30.076409 [ 33000 ] {0841a20e-96c6-4b5b-9faa-4ff6bae3b456} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 747, line 747) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:30.082240 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:30.134131 [ 33000 ] {f789023a-248d-4823-89d5-e3a3c6bcb663} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 748, line 748) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:30.137654 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:30.171167 [ 33000 ] {5c6e20f6-e363-4114-9b34-cd7ed417d66e} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 749, line 749) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:30.174732 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:30.678519 [ 34277 ] {bb4d457c-5bc9-452b-ac16-a88c0c54f7f3} 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.3.20372.altinityantalya (altinity build)) (from [::1]:40884) (comment: 00167_settings_inside_query.sql) (query 1, line 1) (in query: SELECT min(number) FROM system.numbers WHERE toUInt64(number % 1000) IN (SELECT DISTINCT blockSize() FROM system.numbers SETTINGS max_block_size = 123, max_rows_to_read = 1000, read_overflow_mode = 'break') SETTINGS max_rows_to_read = 1000000, read_overflow_mode = 'break';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2afe46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:30.678784 [ 5072 ] {01b1c6f9-ca7b-4b45-ac9c-dc583925f11a} executeQuery: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40880) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x0000000032e93089 6. ./build_docker/./src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000032f9e985 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ac5e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 9. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000303932de 10. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000030390461 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageDistributed* std::construct_at[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, DB::StorageDistributed*>(DB::StorageDistributed*, 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&&) @ 0x0000000028498db1 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, std::allocator, 0>(std::allocator, 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&&) @ 0x0000000028498933 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000028498727 14. ./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 @ 0x0000000028492770 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:28:30.700068 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x0000000032e93089 6. ./build_docker/./src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000032f9e985 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ac5e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 9. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000303932de 10. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000030390461 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageDistributed* std::construct_at[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, DB::StorageDistributed*>(DB::StorageDistributed*, 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&&) @ 0x0000000028498db1 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, std::allocator, 0>(std::allocator, 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&&) @ 0x0000000028498933 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000028498727 14. ./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 @ 0x0000000028492770 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:28:30.743255 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2afe46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:31.312588 [ 33000 ] {fb32182f-e7d0-437a-886b-cb5140c3b076} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 757, line 757) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.07.13 02:28:31.318037 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:31.398490 [ 33000 ] {d8f852cf-92e8-4029-ac18-c9a3fc747dbe} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 758, line 758) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.07.13 02:28:31.408733 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:31.476614 [ 33000 ] {03cfe7e4-af2e-4c6a-b426-a057bc16ea35} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 759, line 759) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.07.13 02:28:31.487681 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:32.970999 [ 33000 ] {87defcff-d5c3-46d7-b4f4-f17879949ec9} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 767, line 767) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:32.979814 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:33.060116 [ 33000 ] {4f0eaabd-51fc-4c01-a1bd-c582853da284} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 768, line 768) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:33.066996 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:33.171894 [ 33000 ] {fa76c1de-387e-4dcf-bb1b-d723301e15fd} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 769, line 769) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.07.13 02:28:33.179208 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:33.453182 [ 33000 ] {eae45685-2da5-4002-9be0-6e33bd5658cb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 772, line 772) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt8(1) as r FORMAT CSV;) 2025.07.13 02:28:33.474787 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:33.813422 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:34.286898 [ 33000 ] {5a2f71fc-c987-4955-a1b9-b0d2742dd0fb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 777, line 777) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) == N as r FORMAT CSV;) 2025.07.13 02:28:34.303839 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:35.020976 [ 33000 ] {1e9fc945-cc7b-4a28-8225-2fc7f5e09f2c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 782, line 782) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt8(-1) as r FORMAT CSV;) 2025.07.13 02:28:35.027586 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:35.843872 [ 33000 ] {368562ad-53bb-4885-8879-8cc705a71de2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 787, line 787) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) == N as r FORMAT CSV;) 2025.07.13 02:28:35.874996 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:36.643028 [ 33000 ] {8c189e78-e438-40b0-829c-e746a8073d52} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 792, line 792) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt16(1) as r FORMAT CSV;) 2025.07.13 02:28:36.647440 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:37.548230 [ 33000 ] {e18a395d-9960-4f44-8736-3b84ccd9e32b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 797, line 797) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) == N as r FORMAT CSV;) 2025.07.13 02:28:37.568670 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:38.477608 [ 33000 ] {403df45d-325b-40fd-9692-e510e14d3a25} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 802, line 802) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt16(-1) as r FORMAT CSV;) 2025.07.13 02:28:38.511231 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:39.544237 [ 33000 ] {474aec6f-88af-4cda-bd31-ce2ece8e3a5a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 807, line 807) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) == N as r FORMAT CSV;) 2025.07.13 02:28:39.622896 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:39.960926 [ 5382 ] {bd4525fc-c2ef-47bf-a8ba-ce7347b2d279} executeQuery: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52488) (comment: 01702_system_numbers_scientific_notation.sql) (query 3, line 3) (in query: select * from numbers_mt('100') format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2166 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:28:39.997383 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2166 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:28:40.118307 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:40.141747 [ 5382 ] {ddac975c-893b-4751-88dd-1fffc8da1baa} executeQuery: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52488) (comment: 01702_system_numbers_scientific_notation.sql) (query 4, line 4) (in query: select * from numbers_mt(inf) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:28:40.149221 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:28:40.276486 [ 5382 ] {ae6759ce-f43c-4e7d-92ea-55681775687e} executeQuery: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52488) (comment: 01702_system_numbers_scientific_notation.sql) (query 5, line 5) (in query: select * from numbers_mt(nan) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:28:40.352136 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:28:40.543055 [ 33000 ] {1b3795c9-a12c-42f0-9297-3d584668071f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 812, line 812) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt32(1) as r FORMAT CSV;) 2025.07.13 02:28:40.556213 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:41.656462 [ 33000 ] {6e1b3b13-9514-4bcc-92b7-9842063f5b25} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 817, line 817) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) == N as r FORMAT CSV;) 2025.07.13 02:28:41.678160 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:42.420297 [ 33000 ] {a4c6a06a-1913-49af-9793-a0b24a70b0e4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 822, line 822) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt32(-1) as r FORMAT CSV;) 2025.07.13 02:28:42.425449 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:42.428646 [ 32979 ] {13f1be67-5cff-4632-b65b-6127ecbb6bee} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39176) (comment: 02362_part_log_merge_algorithm.sql) (in query: DROP DATABASE IF EXISTS test_imq5sis3 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:42.431529 [ 32979 ] {13f1be67-5cff-4632-b65b-6127ecbb6bee} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:42.685665 [ 34273 ] {d0a560b1-e8f8-4bc0-92c8-50cabc934520} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39190) (comment: 02362_part_log_merge_algorithm.sql) (in query: DROP DATABASE IF EXISTS test_imq5sis3 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:28:42.714187 [ 34273 ] {d0a560b1-e8f8-4bc0-92c8-50cabc934520} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:42.864550 [ 5382 ] {4a256c0a-9e4d-4d15-b72a-2e7a99a287d3} executeQuery: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(IntervalMonth, UInt8) which cannot be Nullable: While processing (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17: While processing viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17): While processing toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17), 1): While processing toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17), 1). (INCORRECT_RESULT_OF_SCALAR_SUBQUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52592) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (query 7, line 10) (in query: ALTER TABLE t1 (MODIFY COLUMN `a` Float64 TTL toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', ( SELECT toIntervalMonth(1), 2 FROM t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP )), 1)) settings allow_experimental_parallel_reading_from_replicas = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:230: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded5ba3 6. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:88: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded1836 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 8. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 10. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 12. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 15. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x000000002e1ba681 18. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1532: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc66c 19. ./build_docker/./src/Storages/TTLDescription.cpp:185: DB::buildExpressionAndSets(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x0000000030827c50 20. ./build_docker/./src/Storages/TTLDescription.cpp:236: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000030828989 21. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d173d 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:42.875088 [ 5382 ] {} TCPHandler: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(IntervalMonth, UInt8) which cannot be Nullable: While processing (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17: While processing viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17): While processing toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17), 1): While processing toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery17), 1). (INCORRECT_RESULT_OF_SCALAR_SUBQUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:230: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded5ba3 6. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:88: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded1836 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 8. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 10. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 12. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 15. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x000000002e1ba681 18. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1532: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc66c 19. ./build_docker/./src/Storages/TTLDescription.cpp:185: DB::buildExpressionAndSets(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x0000000030827c50 20. ./build_docker/./src/Storages/TTLDescription.cpp:236: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000030828989 21. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d173d 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:42.987624 [ 33000 ] {96d05047-4493-46c4-bc9a-292e725c7056} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 827, line 827) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) == N as r FORMAT CSV;) 2025.07.13 02:28:42.994870 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:42.996802 [ 5382 ] {ba21c79f-4ab1-4cd1-bbc0-8a795f46068c} executeQuery: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(IntervalMonth, UInt8) which cannot be Nullable: While processing (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18: While processing viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18): While processing toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18), 1): While processing toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18), 1). (INCORRECT_RESULT_OF_SCALAR_SUBQUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52592) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (query 8, line 22) (in query: ALTER TABLE t1 (MODIFY COLUMN `a` Float64 TTL toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', ( SELECT toIntervalMonth(1), 2 FROM t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP )), 1)) settings allow_experimental_parallel_reading_from_replicas = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:230: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded5ba3 6. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:88: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded1836 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 8. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 10. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 12. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 15. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x000000002e1ba681 18. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1532: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc66c 19. ./build_docker/./src/Storages/TTLDescription.cpp:185: DB::buildExpressionAndSets(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x0000000030827c50 20. ./build_docker/./src/Storages/TTLDescription.cpp:236: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000030828989 21. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d173d 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:43.013601 [ 5382 ] {} TCPHandler: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(IntervalMonth, UInt8) which cannot be Nullable: While processing (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18: While processing viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18): While processing toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18), 1): While processing toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_9.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery18), 1). (INCORRECT_RESULT_OF_SCALAR_SUBQUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:230: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded5ba3 6. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:88: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded1836 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 8. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 10. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 12. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002ded0d03 15. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x000000002ded6c1c 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002ded086d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x000000002e1ba681 18. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1532: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc66c 19. ./build_docker/./src/Storages/TTLDescription.cpp:185: DB::buildExpressionAndSets(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x0000000030827c50 20. ./build_docker/./src/Storages/TTLDescription.cpp:236: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000030828989 21. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d173d 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:28:43.107066 [ 3464 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b232ee2b-6954-4990-9e10-0ae434effb11::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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:44.025721 [ 33000 ] {ba738b9c-c533-45c3-b40e-425eebf167a6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 832, line 832) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt64(1) as r FORMAT CSV;) 2025.07.13 02:28:44.052949 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:46.333191 [ 34260 ] {07c56d2d-c846-4cc1-8389-dc561c03badc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=12): While reading or decompressing /var/lib/clickhouse/store/b23/b232ee2b-6954-4990-9e10-0ae434effb11/all_1_6_1/key.bin (position: 16075063, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b7a1cb74258622223c5e0759854f9451821780000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/b23/b232ee2b-6954-4990-9e10-0ae434effb11/all_1_6_1/ in table test_u7lt2reu.num_1 (b232ee2b-6954-4990-9e10-0ae434effb11) located on disk default of type local, from mark 470 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52536) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=0) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, send_logs_level='trace', parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c607083 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:28:46.411968 [ 33000 ] {2286716d-9593-42f5-998a-ada3eb77ccd4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 837, line 837) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) == N as r FORMAT CSV;) 2025.07.13 02:28:46.435539 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:46.468723 [ 34260 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=12): While reading or decompressing /var/lib/clickhouse/store/b23/b232ee2b-6954-4990-9e10-0ae434effb11/all_1_6_1/key.bin (position: 16075063, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b7a1cb74258622223c5e0759854f9451821780000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/b23/b232ee2b-6954-4990-9e10-0ae434effb11/all_1_6_1/ in table test_u7lt2reu.num_1 (b232ee2b-6954-4990-9e10-0ae434effb11) located on disk default of type local, from mark 470 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c607083 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:46.499883 [ 5826 ] {1a83c685-8274-4e41-ba3e-28ec297a57c1} 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]:40202). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x00000000316adce1 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:47.020055 [ 34259 ] {9dfd7093-cf7f-45ea-bd34-4916fe56a0c9} executeQuery: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52604) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:369: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c3a4bd1 6. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321327e9 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:47.062080 [ 34259 ] {} TCPHandler: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:369: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c3a4bd1 6. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321327e9 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:47.109878 [ 33000 ] {5dc51c9e-f255-4844-8171-337372a1b362} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 842, line 842) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt64(-1) as r FORMAT CSV;) 2025.07.13 02:28:47.120310 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:47.981708 [ 34273 ] {d3b34a3a-b45b-4a19-9f8e-d4f4a3fdf7c4} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1246: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddaec97 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:269: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030848a99 22. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 23. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95552 24. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:48.002973 [ 33000 ] {6d575955-ef33-41e8-b8b7-a84a44e24798} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 847, line 847) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) == N as r FORMAT CSV;) 2025.07.13 02:28:48.016656 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:48.061697 [ 34273 ] {d3b34a3a-b45b-4a19-9f8e-d4f4a3fdf7c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52710) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1246: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddaec97 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:269: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030848a99 22. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 23. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95552 24. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:28:48.101732 [ 34273 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1246: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddaec97 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:269: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030848a99 22. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 23. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95552 24. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:28:48.726501 [ 33000 ] {3c1287ee-7e6b-44be-a97b-bb5bee7dd276} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 852, line 852) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt8(1) as r FORMAT CSV;) 2025.07.13 02:28:48.736568 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:49.285370 [ 5476 ] {d854b33a-3a85-4123-849c-60fd7e9a6387} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'idontexist' in scope SELECT 1 FROM idontexist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44788) (comment: 03326_client_ignore_error_multiquery.sh) (query 1, line 1) (in query: SELECT 1 FROM idontexist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:28:49.307214 [ 5476 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'idontexist' in scope SELECT 1 FROM idontexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:28:49.413257 [ 34273 ] {b44c64d0-28bc-462d-a291-d952e0d773b5} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1246: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddaec97 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:269: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030848a99 22. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 23. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95552 24. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:28:49.448629 [ 34273 ] {b44c64d0-28bc-462d-a291-d952e0d773b5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52738) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, send_logs_level='trace', parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1246: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddaec97 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:269: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030848a99 22. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 23. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95552 24. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:28:49.537955 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1246: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddaec97 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:269: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030848a99 22. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 23. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd95552 24. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd79a5f 25. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:28:49.540237 [ 33000 ] {04be263d-3f7d-4f3b-b970-e3fe5316dab1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 857, line 857) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) != N as r FORMAT CSV;) 2025.07.13 02:28:49.545011 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:49.782122 [ 5971 ] {237f2561-91a9-40fc-8f57-54f329f32275} executeQuery: Code: 127. DB::Exception: The 'inverted' index type is deprecated. Please use the 'full_text' index type instead. (ILLEGAL_INDEX) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44806) (comment: 02346_fulltext_index_old_name.sql) (query 3, line 11) (in query: CREATE TABLE tab (`k` UInt64, `s` String, INDEX idx s TYPE inverted(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 22716, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 110, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 9515548, compact_parts_max_granules_to_buffer = 140, compact_parts_merge_max_bytes_to_prefetch_part = 31768804, merge_max_block_size = 1716, old_parts_lifetime = 313., prefer_fetch_merged_part_size_threshold = 8484222577, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4680539994, index_granularity_bytes = 757554, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 44, 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 = 17931, primary_key_compress_block_size = 27327, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:800: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc6ed75 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:28:49.791357 [ 5971 ] {} TCPHandler: Code: 127. DB::Exception: The 'inverted' index type is deprecated. Please use the 'full_text' index type instead. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:800: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc6ed75 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:28:50.292651 [ 33000 ] {a56f401a-7017-4e8a-8c94-16a450759301} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 862, line 862) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt8(-1) as r FORMAT CSV;) 2025.07.13 02:28:50.296289 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:51.131385 [ 6024 ] {56076c58-ae38-4b72-9745-127a003ef01b} executeQuery: Code: 127. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. (ILLEGAL_INDEX) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43894) (comment: 02346_fulltext_index_old_name.sql) (query 9, line 21) (in query: SELECT `__table1`.`k` AS `k`, `__table1`.`s` AS `s` FROM `test_11`.`tab` AS `__table1` WHERE `__table1`.`s` = 'bc'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.131416 [ 5380 ] {7143b693-2aaa-47a0-91f9-c3175f26f296} executeQuery: Code: 127. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. (ILLEGAL_INDEX) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34432) (comment: 02346_fulltext_index_old_name.sql) (query 9, line 21) (in query: SELECT `__table1`.`k` AS `k`, `__table1`.`s` AS `s` FROM `test_11`.`tab` AS `__table1` WHERE `__table1`.`s` = 'bc'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.132086 [ 3815 ] {86ad2929-b988-4dad-8934-9d2317d47905} executeQuery: Code: 127. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. (ILLEGAL_INDEX) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55556) (comment: 02346_fulltext_index_old_name.sql) (query 9, line 21) (in query: SELECT `__table1`.`k` AS `k`, `__table1`.`s` AS `s` FROM `test_11`.`tab` AS `__table1` WHERE `__table1`.`s` = 'bc'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.132210 [ 6126 ] {782a13aa-a3e0-4820-8b91-0b199cf18c47} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44892) (comment: 01666_merge_tree_max_query_limit.sh) (query 1, line 1) (in query: select * from simple), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000017f9decf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8712: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x0000000030d552f6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8738: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x0000000030d55f59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1027: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000030e31e65 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321bab40 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.134170 [ 6024 ] {} TCPHandler: Code: 127. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.140717 [ 3815 ] {} TCPHandler: Code: 127. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.141491 [ 5380 ] {} TCPHandler: Code: 127. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.161462 [ 6126 ] {} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000017f9decf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8712: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x0000000030d552f6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8738: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x0000000030d55f59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1027: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000030e31e65 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321bab40 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.165462 [ 5971 ] {0b059f27-b125-44fc-91b6-8b744d7b824f} executeQuery: Code: 127. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 : While executing Remote. (ILLEGAL_INDEX) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44806) (comment: 02346_fulltext_index_old_name.sql) (query 9, line 21) (in query: -- To encourage users to migrate to the new index type, we now throw an exception when the index is used by queries. SELECT * from tab WHERE s = 'bc';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:28:51.187777 [ 33000 ] {76fce367-a12d-43f8-8a1f-ae1a9c6b45de} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 867, line 867) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) != N as r FORMAT CSV;) 2025.07.13 02:28:51.192020 [ 5971 ] {} TCPHandler: Code: 127. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Indexes of type 'inverted' are no longer supported. Please drop and recreate the index as type 'full_text'. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexFullText.cpp:751: DB::MergeTreeIndexFullText::createIndexGranule() const @ 0x0000000030e69b2e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:85: DB::MergeTreeIndexReader::read(std::shared_ptr&) @ 0x0000000030e7bc8f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1544: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000030e33c63 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:732: 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)::$_0::operator()(unsigned long) const @ 0x0000000030e2ebc6 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: 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) @ 0x0000000030e2ae2b 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 : While executing Remote. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.197250 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:51.843542 [ 34272 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.844519 [ 34272 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:28:51.866328 [ 3885 ] {15a4a8ae-0c88-4fe6-aa2c-cadd2b6995e0} executeQuery: Code: 452. DB::Exception: Received from 127.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44910) (comment: 02768_cse_nested_distributed.sql) (query 1, line 1) (in query: with (select count() > 0 from remote('127.2', system.settings)) as s select s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:28:51.896962 [ 33000 ] {3b4bc752-1081-4c57-a4c6-af2f529b47b6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 872, line 872) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt16(1) as r FORMAT CSV;) 2025.07.13 02:28:51.902617 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:51.941368 [ 3885 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:631: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc1a6ca 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3874: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10619 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1247: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c65 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10c0a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:28:52.539199 [ 33000 ] {bfd70691-8349-43c6-8fba-0ccd0057303b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 877, line 877) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) != N as r FORMAT CSV;) 2025.07.13 02:28:52.551847 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:52.855741 [ 29256 ] {72a6815e-823b-4998-bbd9-3bed1f3d3a8b} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45004) (comment: 01666_merge_tree_max_query_limit.sh) (query 1, line 1) (in query: select * from simple where i = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000017f9decf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8712: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x0000000030d552f6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8738: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x0000000030d55f59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1027: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000030e31e65 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321bab40 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:28:52.869994 [ 29256 ] {} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000017f9decf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8712: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x0000000030d552f6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8738: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x0000000030d55f59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1027: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000030e31e65 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321bab40 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:28:53.190707 [ 6126 ] {275329cc-b459-444d-bdc4-3b1a1b32068c} executeQuery: Code: 36. DB::Exception: Explicitly specified value of minimum unit argument (hours) for function formatReadableTimeDelta must not be greater than maximum unit value (seconds).: In scope SELECT formatReadableTimeDelta(1.1, 'seconds', 'hours'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44984) (comment: 02887_format_readable_timedelta_subseconds.sql) (query 3, line 15) (in query: -- Check exception is thrown SELECT formatReadableTimeDelta(1.1, 'seconds', 'hours');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&, String, std::basic_string_view>&>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity>&>::type>, std::basic_string_view>&, String&&, std::basic_string_view>&) @ 0x000000001ae26c8f 5. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae254fd 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:28:53.196933 [ 6126 ] {} TCPHandler: Code: 36. DB::Exception: Explicitly specified value of minimum unit argument (hours) for function formatReadableTimeDelta must not be greater than maximum unit value (seconds).: In scope SELECT formatReadableTimeDelta(1.1, 'seconds', 'hours'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&, String, std::basic_string_view>&>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity>&>::type>, std::basic_string_view>&, String&&, std::basic_string_view>&) @ 0x000000001ae26c8f 5. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae254fd 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:28:53.197727 [ 33000 ] {fb3b35e0-0f6e-422e-b9e4-a87d12e7a095} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 882, line 882) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt16(-1) as r FORMAT CSV;) 2025.07.13 02:28:53.207394 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:53.753784 [ 33000 ] {13d0516f-02d1-4b58-9b84-c92682dcf33c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 887, line 887) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) != N as r FORMAT CSV;) 2025.07.13 02:28:53.772482 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:54.373821 [ 33000 ] {76b81428-04c7-46df-9dac-b761ce7f8402} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 892, line 892) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt32(1) as r FORMAT CSV;) 2025.07.13 02:28:54.379495 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:55.103329 [ 33000 ] {b0410455-120e-4f4a-9695-856279c461fb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 897, line 897) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) != N as r FORMAT CSV;) 2025.07.13 02:28:55.117701 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:55.211014 [ 2824 ] {6e12e2bf-24c1-414b-bf82-d78eac2fdcee} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45066) (comment: 01666_merge_tree_max_query_limit.sh) (query 1, line 1) (in query: select * from simple where i = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000017f9decf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8712: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x0000000030d552f6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8738: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x0000000030d55f59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1027: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000030e31e65 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321bab40 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:28:55.226850 [ 2824 ] {} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000017f9decf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8712: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x0000000030d552f6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8738: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x0000000030d55f59 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1027: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x0000000030e31e65 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321bab40 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:28:55.795819 [ 5476 ] {long_running_query-test_5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44860) (comment: 01666_merge_tree_max_query_limit.sh) (query 1, line 1) (in query: select sleepEachRow(0.1) from simple settings max_block_size = 1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:28:55.800276 [ 5476 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:55.838528 [ 33000 ] {758b2c09-b2bd-4336-9ca4-b044b26b1172} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 902, line 902) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt32(-1) as r FORMAT CSV;) 2025.07.13 02:28:55.925221 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:55.969728 [ 33006 ] {4d8c15ce-c61b-47b1-9ee1-70a7facb4378} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58414) (comment: 02366_kql_func_string.sql) (query 165, line 190) (in query: print extract_json('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000017d09191 6. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017d08135 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:28:55.993680 [ 33006 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000017d09191 6. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017d08135 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:28:56.062952 [ 33006 ] {1767196a-9044-498b-a93b-65f43e839ced} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58414) (comment: 02366_kql_func_string.sql) (query 166, line 191) (in query: print extract_json('a', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000017d09191 6. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017d08135 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:28:56.075808 [ 33006 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000017d09191 6. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017d08135 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:28:56.700610 [ 33000 ] {2ef2b459-d2c6-4af9-9d53-51d7162bcc5b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 907, line 907) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) != N as r FORMAT CSV;) 2025.07.13 02:28:56.722692 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:56.758841 [ 5379 ] {0ef59c23-7572-4e79-94c8-00cccac70eaf} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45190) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:56.759961 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:28:56.771314 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:28:56.780181 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:56.782337 [ 10341 ] {b6c4d791-892d-49a1-98de-665008f04ee5} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45098) (comment: 03222_datetime64_small_value_const.sql) (query 3, line 5) (in query: select *, (select toDateTime64(0, 3)) from remote('127.0.0.1', system.one) settings prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:28:56.815789 [ 10341 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:28:57.074529 [ 46286 ] {e410bf8f-f30a-4502-990b-85b96cd597b9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45360) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:57.086754 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:57.850605 [ 5971 ] {f4638996-2b0e-49ec-9dde-076ed08055ff} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45464) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:57.878566 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:57.958364 [ 33000 ] {c3dcdfac-e0bf-47d0-b679-5ff601495afe} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 912, line 912) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt64(1) as r FORMAT CSV;) 2025.07.13 02:28:57.968884 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:58.012211 [ 3815 ] {11911f26-5967-4146-b988-962e854657ba} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45500) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.050046 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.063006 [ 6024 ] {d690d5d9-998f-47c9-8c73-389e6b8d9991} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45480) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.072668 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.195832 [ 34340 ] {e5362574-ce6e-4bb7-8f52-74103b5df25a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45524) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.253268 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.486075 [ 34275 ] {77e99fc4-2d44-4328-a6e1-4703d8c69374} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45616) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22ac3c 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b63a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22cd32 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 20. ./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) @ 0x000000002e1ba078 21. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc61d 22. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f344f 23. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:28:58.519278 [ 34275 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22ac3c 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b63a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22cd32 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 20. ./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) @ 0x000000002e1ba078 21. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc61d 22. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f344f 23. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:28:58.614495 [ 34273 ] {a02b962a-68bf-4a0b-a2d8-8b2ea9dfff6a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45680) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.626021 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.679603 [ 5380 ] {65ba4a1e-07ed-43ba-86b9-11bca09bb18b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45720) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.696025 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:58.719995 [ 34275 ] {d6277f00-1e23-42d4-a71c-56c34b09d39e} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45616) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22ac3c 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b63a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22cd32 27. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 28. ./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) @ 0x000000002e1ba078 29. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc61d 30. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f344f 31. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 2025.07.13 02:28:58.730969 [ 34275 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22ac3c 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b63a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b91f 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22d2d0 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000002e22cd32 27. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000002e22b92d 28. ./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) @ 0x000000002e1ba078 29. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000002e1bc61d 30. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f344f 31. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 2025.07.13 02:28:58.829046 [ 33000 ] {bfef9371-6382-4db0-870e-80cc62a87a7f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 917, line 917) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) != N as r FORMAT CSV;) 2025.07.13 02:28:58.833672 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:59.074653 [ 6126 ] {3cb507e3-d971-4449-b175-449b0e58cb50} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45756) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.084641 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.244407 [ 46285 ] {6019f727-7fef-4c6a-86f1-8509fd22c21c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35558) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.248523 [ 3816 ] {cbb3f220-bcbd-4b86-8c87-9a170762a091} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35512) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.269985 [ 46285 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.272184 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.558703 [ 33000 ] {9e39506d-8135-45bb-aa69-2d6cbc77e59e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 922, line 922) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt64(-1) as r FORMAT CSV;) 2025.07.13 02:28:59.587531 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:28:59.843372 [ 10341 ] {f33d6520-eff6-496d-941f-099933dacba9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35738) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.872633 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.927765 [ 46282 ] {a500967d-f227-4a82-b137-686199df9a79} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35810) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:28:59.942560 [ 46282 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.032499 [ 46286 ] {b4aa9f7f-04cb-4ab0-940c-2c0765a47777} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35816) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.058052 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.212102 [ 3816 ] {35241ff7-fb9b-4383-b1d0-6aa7a01761ea} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35900) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.223796 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.234648 [ 33006 ] {2453705c-d000-4166-b50c-65d5c3173847} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=865). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58414) (comment: 02366_kql_func_string.sql) (query 188, line 215) (in query: print '-- strcat_delim (https://docs.microsoft.com/en-us/azure/data-explorer/kusto/query/strcat-delimfunction); TODO: only support string now.';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.249276 [ 33000 ] {7a08d17a-8f8a-42a5-a72a-eaaac0ed1aaa} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 927, line 927) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) != N as r FORMAT CSV;) 2025.07.13 02:29:00.267824 [ 33006 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=865). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.271355 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:00.398346 [ 46285 ] {2d375374-02db-4c53-ab97-8b54cd896937} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35964) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.409056 [ 46285 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:00.995763 [ 29256 ] {2e69ca61-d63f-4327-b173-98a44c0dee1e} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36080) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.004417 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.192937 [ 7056 ] {e02d6abb-8101-4ebd-b2c4-3bcad536abcd} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36150) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.214034 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.242817 [ 33000 ] {af9f93d0-e90b-452d-b0e6-9f54c311d5b2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 932, line 932) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt8(1) as r FORMAT CSV;) 2025.07.13 02:29:01.264106 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:01.558249 [ 46294 ] {fbc37a8c-2214-4b98-9789-e8ad13ddb34f} executeQuery: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36116) (comment: 01702_system_numbers_scientific_notation.sql) (query 3, line 3) (in query: select * from numbers_mt('100') format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2166 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.580904 [ 46294 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2166 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.788719 [ 46294 ] {48b78e12-6d06-4ef4-b8b4-da7a33c39051} executeQuery: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36116) (comment: 01702_system_numbers_scientific_notation.sql) (query 4, line 4) (in query: select * from numbers_mt(inf) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:29:01.804988 [ 46294 ] {} TCPHandler: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:29:02.007996 [ 46294 ] {7eaa7c88-9dfb-49a5-9f70-05be294d609f} executeQuery: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36116) (comment: 01702_system_numbers_scientific_notation.sql) (query 5, line 5) (in query: select * from numbers_mt(nan) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:29:02.015049 [ 46294 ] {} TCPHandler: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a0ee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:29:02.548925 [ 33000 ] {551202cd-0715-4a75-8638-296a3833fd9f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 937, line 937) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) < N as r FORMAT CSV;) 2025.07.13 02:29:02.552368 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:02.858000 [ 5826 ] {5fe28639-394c-45d6-b926-da90235884ac} executeQuery: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36574) (comment: 01021_only_tuple_columns.sql) (query 1, line 2) (in query: CREATE TABLE test (`x` Tuple(UInt64, UInt64)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 38772, 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 = 317031509, compact_parts_max_bytes_to_buffer = 121402716, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 31990, merge_max_block_size = 17043, old_parts_lifetime = 280., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 20016466, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 79179, primary_key_compress_block_size = 98651, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:02.864293 [ 5826 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:03.035002 [ 5476 ] {b7cae6be-594e-4778-ad19-83889a53549a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36598) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:03.056032 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:03.306657 [ 32979 ] {62a2d0d0-e5b1-4ae2-8a0c-cebcf50a8060} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36694) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:03.324427 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:03.452551 [ 33000 ] {ba7a7c65-e3b9-459b-a301-45e8e6fe05b0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 942, line 942) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt8(-1) as r FORMAT CSV;) 2025.07.13 02:29:03.456492 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:03.520636 [ 29256 ] {c76af21c-fabb-41fc-a4b7-89c52e84566c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36826) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:03.559877 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:04.293345 [ 34260 ] {9bf3814b-9b2b-41a3-9c7c-00ae09b8ab55} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: while executing 'FUNCTION toUInt64(val :: 0) -> toUInt64(__table1.val) LowCardinality(UInt64) : 2'. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36572) (comment: 02480_suspicious_lowcard_in_key.sql) (query 5, line 9) (in query: select count() from test where toUInt64(val) = -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/Functions/FunctionsConversion.h:1843: 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*) @ 0x000000002b0875aa 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b083246 7. ./src/Core/callOnTypeIndex.h:267: 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&&) @ 0x000000002b00eee5 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01c13e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01afa3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc823 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dcb897 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:29:04.330234 [ 34260 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: while executing 'FUNCTION toUInt64(val :: 0) -> toUInt64(__table1.val) LowCardinality(UInt64) : 2'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/Functions/FunctionsConversion.h:1843: 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*) @ 0x000000002b0875aa 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b083246 7. ./src/Core/callOnTypeIndex.h:267: 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&&) @ 0x000000002b00eee5 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01c13e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b01afa3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc823 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dcb897 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dcb620 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:04.410416 [ 33000 ] {f547db92-7c30-449b-88b8-1bced4caf226} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 947, line 947) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) < N as r FORMAT CSV;) 2025.07.13 02:29:04.415114 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:04.543659 [ 36852 ] {e67da500-deb4-4c4b-975c-28a147988d4b} RestorerFromBackup: Tables test_elrss4e8.mv in backup depend on test_elrss4e8.src, but seems like test_elrss4e8.src is not in the backup and does not exist. Will try to ignore that and restore tables 2025.07.13 02:29:04.856415 [ 5379 ] {2a2a1757-8bed-4e3c-8f6a-ba5f6646fe9c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37118) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:04.871317 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:04.992013 [ 5072 ] {df4b33c1-34c7-45e3-bf8c-1cfc936e6e08} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=2): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36784) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', join_algorithm='hash'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221e500 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:29:04.994020 [ 34277 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60248, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:04.996123 [ 34277 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60248, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:05.007784 [ 5072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=2): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221e500 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003182458b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.173722 [ 33000 ] {b5db45ee-bdef-48f7-882b-0612bbc5a8fb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 952, line 952) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt16(1) as r FORMAT CSV;) 2025.07.13 02:29:05.177732 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:05.560863 [ 46282 ] {9da85969-27ac-414b-a9b1-bcc4bfcce6d6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37380) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.576716 [ 46282 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.576945 [ 46285 ] {c0423331-06d1-40a7-915e-26eccf26588c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37394) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.597551 [ 46285 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.618237 [ 33006 ] {da723a34-a214-4a2a-86ab-571c92b5d15e} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37378) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.633543 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.709100 [ 5826 ] {e5022cdb-9d80-424d-b325-f5d16ac47665} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41556) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: DROP DATABASE IF EXISTS test_u7lt2reu SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:29:05.710657 [ 5826 ] {e5022cdb-9d80-424d-b325-f5d16ac47665} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:06.049765 [ 33000 ] {6ac62633-9d0e-4f53-90ed-88091ff6a1a3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 957, line 957) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) < N as r FORMAT CSV;) 2025.07.13 02:29:06.053592 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:06.891681 [ 5971 ] {ad88caf8-9f37-40ee-b526-0aa9f591cd4e} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37780) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:06.909635 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:06.994682 [ 33000 ] {ad4b1a81-6b3f-4dbf-abcb-a29b6283e1bd} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 962, line 962) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt16(-1) as r FORMAT CSV;) 2025.07.13 02:29:07.005245 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:07.069752 [ 5382 ] {0745a9fb-110e-4a24-97b6-e4830e9aed32} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37732) (comment: 00916_create_or_replace_view.sql) (query 4, line 6) (in query: CREATE OR REPLACE VIEW t AS SELECT number+1 AS next_number FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:07.086956 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:07.289678 [ 7056 ] {ede1cb9c-4ae4-4acf-a88e-cac36e01d813} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37858) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:07.299407 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:07.345819 [ 34340 ] {481f9a2e-9615-46ef-87fd-6efc3ba5d1e9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37880) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:07.358834 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:07.790813 [ 33000 ] {ca583992-2344-4bd3-81c5-0b46143229dc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 967, line 967) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) < N as r FORMAT CSV;) 2025.07.13 02:29:07.798723 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:08.049389 [ 34275 ] {313cb993-edf0-4f91-ba8e-59ffddc2fe5a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38170) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:08.065369 [ 7056 ] {39cdfebb-7a0b-4258-8872-70c984e5e9a1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38138) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:08.072923 [ 34275 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:08.084949 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:08.464676 [ 33000 ] {c986edda-4f29-491a-a5d4-de19321c724b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 972, line 972) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt32(1) as r FORMAT CSV;) 2025.07.13 02:29:08.480243 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:09.190828 [ 3815 ] {dbd7c9bf-7fee-457b-8a53-221bf7bec9ae} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52816) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:09.208084 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:09.261988 [ 33000 ] {2d56ecce-3480-42c5-9a39-824c8bb189ce} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 977, line 977) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) < N as r FORMAT CSV;) 2025.07.13 02:29:09.266197 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:09.530479 [ 7056 ] {568bb374-27b5-40bb-a3ae-492e45c5a202} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52886) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:09.545598 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:09.951177 [ 33000 ] {8b94f20f-7f3f-4a22-a87d-0fb2a0a77f06} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 982, line 982) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt32(-1) as r FORMAT CSV;) 2025.07.13 02:29:09.955209 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:10.071520 [ 3648 ] {1afc0bb2-c8af-4967-97e7-11655737d3fa} executeQuery: Code: 57. DB::Exception: Table test_13.ddl_test_for_opentelemetry already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02423_ddl_for_opentelemetry.sh) (in query: /* ddl_entry=query-0000000029 */ CREATE TABLE test_13.ddl_test_for_opentelemetry UUID 'dec7fd5c-5477-4c07-9c52-4e14a7f0edfa' (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 51602, min_bytes_for_wide_part = 854506836, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 121, min_bytes_for_full_part_storage = 280924733, compact_parts_max_bytes_to_buffer = 192417785, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 29324901, merge_max_block_size = 19895, old_parts_lifetime = 379., 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 = 433427032, index_granularity_bytes = 9327891, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 67, 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 = 58452, primary_key_compress_block_size = 75827, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5cb52f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5bf9d6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.076509 [ 3648 ] {1afc0bb2-c8af-4967-97e7-11655737d3fa} DDLWorker: Query /* ddl_entry=query-0000000029 */ CREATE TABLE test_13.ddl_test_for_opentelemetry UUID 'dec7fd5c-5477-4c07-9c52-4e14a7f0edfa' (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 51602, min_bytes_for_wide_part = 854506836, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 121, min_bytes_for_full_part_storage = 280924733, compact_parts_max_bytes_to_buffer = 192417785, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 29324901, merge_max_block_size = 19895, old_parts_lifetime = 379., 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 = 433427032, index_granularity_bytes = 9327891, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 67, 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 = 58452, primary_key_compress_block_size = 75827, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true wasn't finished successfully: Code: 57. DB::Exception: Table test_13.ddl_test_for_opentelemetry already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5cb52f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5bf9d6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:10.205868 [ 5971 ] {0a24484a-6047-456b-8f77-7045fc9ef5aa} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53200) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.206075 [ 33006 ] {955ba227-d04e-496b-a664-490593eb6ec9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53206) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.217392 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.231334 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.241020 [ 46285 ] {38f373a8-f91e-4695-a141-03e4c274753a} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_13.ddl_test_for_opentelemetry already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)). (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53002) (comment: 02423_ddl_for_opentelemetry.sh) (query 1, line 1) (in query: CREATE TABLE test_13.ddl_test_for_opentelemetry ON CLUSTER test_shard_localhost (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 51602, min_bytes_for_wide_part = 854506836, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 121, min_bytes_for_full_part_storage = 280924733, compact_parts_max_bytes_to_buffer = 192417785, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 29324901, merge_max_block_size = 19895, old_parts_lifetime = 379., 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 = 433427032, index_granularity_bytes = 9327891, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 67, 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 = 58452, primary_key_compress_block_size = 75827, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e29aa5a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6243a1 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.281612 [ 46285 ] {} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_13.ddl_test_for_opentelemetry already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e29aa5a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6243a1 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.425429 [ 3766 ] {cc9fd6fe-a811-412e-b2b4-2c92aeafa943} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53276) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.447016 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.491266 [ 2824 ] {max_concurrent_queries_29950} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): (while reading column j): (while reading from part /var/lib/clickhouse/store/e7d/e7d73b60-eb69-4330-94f5-cd8813d169a2/all_1_1_0/ in table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2) located on disk default of type local, from mark 2128 with max_rows_to_read = 5000): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45118) (comment: 01666_merge_tree_max_query_limit.sh) (query 1, line 1) (in query: select i from simple where j in (select i from simple where i < 10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000032da38fd 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c6123e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:29:10.492220 [ 46294 ] {a5862277-e31f-483f-af43-31e8c1a207f8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53320) (comment: 03237_create_or_replace_view_atomically_with_atomic_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_11_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.540511 [ 2824 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): (while reading column j): (while reading from part /var/lib/clickhouse/store/e7d/e7d73b60-eb69-4330-94f5-cd8813d169a2/all_1_1_0/ in table test_5.simple (e7d73b60-eb69-4330-94f5-cd8813d169a2) located on disk default of type local, from mark 2128 with max_rows_to_read = 5000): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000032da38fd 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c6123e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.543610 [ 46294 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2168: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc8475d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d936 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:10.563446 [ 33000 ] {93c83929-24a5-4f4c-8f4c-fa8d39c3be48} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 987, line 987) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) < N as r FORMAT CSV;) 2025.07.13 02:29:10.569463 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:11.021917 [ 29256 ] {a7eacb3b-7dd8-46a5-938a-c006b59bf12e} executeQuery: Code: 60. DB::Exception: Table test_elrss4e8.dst does not exist. Maybe you meant test_13.dst?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53410) (comment: 02907_backup_mv_with_no_source_table.sh) (query 1, line 2) (in query: drop table mv;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304deb2e 9. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304edcaf 10. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b315 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:29:11.048478 [ 29256 ] {} TCPHandler: Code: 60. DB::Exception: Table test_elrss4e8.dst does not exist. Maybe you meant test_13.dst?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304deb2e 9. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304edcaf 10. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b315 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:29:11.260680 [ 34340 ] {716d4c19-571a-4515-a3ba-068805176e92} executeQuery: Code: 60. DB::Exception: Table test_elrss4e8.dst does not exist. Maybe you meant test_13.dst?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57800) (comment: 02907_backup_mv_with_no_source_table.sh) (in query: DROP DATABASE IF EXISTS test_elrss4e8 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304deb2e 9. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304edcaf 10. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b315 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:29:11.265070 [ 33000 ] {9a31983b-e13c-4003-a84f-3b1f5996daa6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 992, line 992) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt64(1) as r FORMAT CSV;) 2025.07.13 02:29:11.265085 [ 34340 ] {716d4c19-571a-4515-a3ba-068805176e92} DynamicQueryHandler: Code: 60. DB::Exception: Table test_elrss4e8.dst does not exist. Maybe you meant test_13.dst?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304deb2e 9. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304edcaf 10. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b315 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:11.294806 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:11.920888 [ 33000 ] {cda9dae9-32f8-49a7-b7f4-db53cc0cc4a7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 997, line 997) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) < N as r FORMAT CSV;) 2025.07.13 02:29:11.925166 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:12.498264 [ 33000 ] {d1a7cb0a-671a-40e8-acd7-ed76ed0bdc14} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1002, line 1002) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt64(-1) as r FORMAT CSV;) 2025.07.13 02:29:12.510510 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:13.122361 [ 33000 ] {417b5f5e-7b02-421d-8efc-0dff0a2c08be} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1007, line 1007) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) < N as r FORMAT CSV;) 2025.07.13 02:29:13.125562 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:13.594560 [ 33000 ] {a2646138-bb3c-477b-a9cf-1cc5ab1a2727} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1012, line 1012) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt8(1) as r FORMAT CSV;) 2025.07.13 02:29:13.605801 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:14.065951 [ 33000 ] {a8b63b2d-af54-49d6-8c25-41284f40bc62} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1017, line 1017) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) <= N as r FORMAT CSV;) 2025.07.13 02:29:14.085145 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:14.671190 [ 33000 ] {67f5b210-2e40-4335-bb60-de841ec295af} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1022, line 1022) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt8(-1) as r FORMAT CSV;) 2025.07.13 02:29:14.699330 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:15.524330 [ 33000 ] {fe148430-e399-4db3-b3c5-b83690a59c7b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1027, line 1027) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) <= N as r FORMAT CSV;) 2025.07.13 02:29:15.535237 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:16.374696 [ 3648 ] {b248811f-b8d4-446d-9b93-bc63eab62d60} executeQuery: Code: 60. DB::Exception: Table test_13.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02423_ddl_for_opentelemetry.sh) (in query: /* ddl_entry=query-0000000030 */ DROP TABLE test_13.ddl_test_for_opentelemetry_non_exist), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5cb52f 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5bf9d6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:29:16.384159 [ 3648 ] {b248811f-b8d4-446d-9b93-bc63eab62d60} DDLWorker: Query /* ddl_entry=query-0000000030 */ DROP TABLE test_13.ddl_test_for_opentelemetry_non_exist wasn't finished successfully: Code: 60. DB::Exception: Table test_13.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5cb52f 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5bf9d6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5eaf34 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:16.477888 [ 46294 ] {b7ce3688-5a1b-4e3b-be8c-d5b8c92d694b} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Table test_13.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53614) (comment: 02423_ddl_for_opentelemetry.sh) (query 1, line 1) (in query: DROP TABLE test_13.ddl_test_for_opentelemetry_non_exist ON CLUSTER test_shard_localhost), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e29aa5a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6243a1 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:29:16.487758 [ 46294 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Table test_13.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e29aa5a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6243a1 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:29:16.488752 [ 33000 ] {0585b698-f96a-4b87-ba62-40411765fa12} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1032, line 1032) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt16(1) as r FORMAT CSV;) 2025.07.13 02:29:16.510659 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:16.707151 [ 3462 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {63667ff6-b6f5-414a-9058-bdd20928b151::202507_1_101_20}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:17.034485 [ 33000 ] {16982312-a471-4449-8cc0-6336e56cfeaf} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1037, line 1037) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) <= N as r FORMAT CSV;) 2025.07.13 02:29:17.038680 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:17.131786 [ 34259 ] {b8c56b6e-50eb-404f-881f-759489430e43} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=5): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53218) (comment: 03008_optimize_equal_ranges.sql) (query 16, line 22) (in query: SELECT used_aggregate_functions[1] AS func, Settings['max_threads'] AS threads, ProfileEvents['AggregationOptimizedEqualRangesOfKeys'] > 0 FROM system.query_log WHERE type = 'QueryFinish' AND current_database = currentDatabase() AND query LIKE '%SELECT%FROM%t_optimize_equal_ranges%' ORDER BY func, threads;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 13. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e4e2b 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221e500 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 2025.07.13 02:29:17.170795 [ 4694 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55858, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:17.171178 [ 34272 ] {80626001-5de2-48f1-8dd5-3c38438e6430} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:46450). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46450) (comment: 03008_optimize_equal_ranges.sql) (query 16, line 22) (in query: SELECT `__table1`.`used_aggregate_functions`[1] AS `func`, `__table1`.`Settings`['max_threads'] AS `threads`, (`__table1`.`ProfileEvents`['AggregationOptimizedEqualRangesOfKeys']) > 0 AS `greater(arrayElement(ProfileEvents, 'AggregationOptimizedEqualRangesOfKeys'), 0)` FROM `system`.`query_log` AS `__table1` WHERE (`__table1`.`type` = 'QueryFinish') AND (`__table1`.`current_database` = _CAST('test_nlrajih7', 'String')) AND (`__table1`.`query` LIKE '%SELECT%FROM%t_optimize_equal_ranges%') ORDER BY `__table1`.`used_aggregate_functions`[1] ASC, `__table1`.`Settings`['max_threads'] ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:17.171515 [ 4694 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55858, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:17.180751 [ 34272 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:46450). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:17.277102 [ 34259 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=5): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 13. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e4e2b 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f15ef 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221e500 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:17.578704 [ 33000 ] {c646befb-2d68-4edf-8375-afd8b54cc13f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1042, line 1042) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt16(-1) as r FORMAT CSV;) 2025.07.13 02:29:17.581681 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:18.089275 [ 33000 ] {810f2725-17d3-4ae6-9508-f82121471d9a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1047, line 1047) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) <= N as r FORMAT CSV;) 2025.07.13 02:29:18.096268 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:18.748153 [ 33000 ] {74ac95d6-97b2-4923-bc35-169a7a9640bb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1052, line 1052) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt32(1) as r FORMAT CSV;) 2025.07.13 02:29:18.758455 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:18.887629 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:19.131554 [ 4938 ] {873d5ad2-e9ee-4471-9497-e38d44df33b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50992) (comment: 02420_final_setting_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_cxtfht91 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:29:19.136338 [ 4938 ] {873d5ad2-e9ee-4471-9497-e38d44df33b1} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:19.521653 [ 33000 ] {174bd04e-cd71-43f8-b0b1-5fceb54da2b2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1057, line 1057) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) <= N as r FORMAT CSV;) 2025.07.13 02:29:19.535698 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:20.216176 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:20.225626 [ 33000 ] {9df918db-32d6-497b-b9fd-3fbf42c38635} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1062, line 1062) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt32(-1) as r FORMAT CSV;) 2025.07.13 02:29:20.232317 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:20.882562 [ 33000 ] {81710037-af41-450a-a33a-8ed2f69c0e58} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1067, line 1067) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) <= N as r FORMAT CSV;) 2025.07.13 02:29:20.889220 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:21.491853 [ 33000 ] {a389078b-5889-412f-91e5-5ec139335a10} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1072, line 1072) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt64(1) as r FORMAT CSV;) 2025.07.13 02:29:21.504684 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:22.148813 [ 33000 ] {233a5767-9498-4931-a3dc-29c9dbb7f0ce} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1077, line 1077) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) <= N as r FORMAT CSV;) 2025.07.13 02:29:22.225585 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:22.596346 [ 33000 ] {1a349e49-e44e-4603-8ee8-e9d66d53b270} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1082, line 1082) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt64(-1) as r FORMAT CSV;) 2025.07.13 02:29:22.637242 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:22.957519 [ 33000 ] {1dbc2865-da3a-4592-b8ee-880325f9b156} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1087, line 1087) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) <= N as r FORMAT CSV;) 2025.07.13 02:29:22.961380 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:23.238841 [ 33000 ] {aa24ccec-434d-4846-a24f-241231c52d52} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1092, line 1092) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt8(1) as r FORMAT CSV;) 2025.07.13 02:29:23.242525 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:23.830662 [ 33000 ] {c2350fe6-3990-4dc4-a4cd-b167748e9a21} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1097, line 1097) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) > N as r FORMAT CSV;) 2025.07.13 02:29:23.835184 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:24.263075 [ 5380 ] {3e5b0c92-c928-4ab6-b907-e5a4916a6f14} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33418) (comment: 00732_quorum_insert_lost_part_and_alive_part_zookeeper_long.sql) (query 13, line 24) (in query: INSERT INTO quorum2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x0000000031178a93 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003119bc34 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003119b7f8 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000031176164 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003115fb50 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031174fa1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc48c1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:29:24.271447 [ 5380 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x0000000031178a93 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003119bc34 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003119b7f8 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000031176164 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003115fb50 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031174fa1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc48c1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:29:24.416989 [ 33000 ] {3814be77-1c96-4747-a261-6819313cad47} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1102, line 1102) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt8(-1) as r FORMAT CSV;) 2025.07.13 02:29:24.421161 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:24.695561 [ 3456 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {43bad8a0-4af4-418c-a697-df1af6f3c7f4::202507_60_105_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:24.925538 [ 33000 ] {acfa9022-6638-448b-baa3-9321ba312c8a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1107, line 1107) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) > N as r FORMAT CSV;) 2025.07.13 02:29:24.929183 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:24.982868 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:29:24.984605 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:29:24.988416 [ 6126 ] {7ad56094-1831-4152-be35-305ba5d4c590} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33460) (comment: 01104_distributed_one_test.sql) (query 13, line 22) (in query: SELECT 'remote_0', toUInt8(1) AS dummy FROM remote('127.0.0.2', system, one) AS o WHERE o.dummy = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:29:25.036151 [ 6126 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.153606 [ 6024 ] {10c286af-1bdd-4cde-ba6b-02e28009463d} AsynchronousInsertQueue: Setting 'async_insert_busy_timeout_min_ms'=500 is greater than 'async_insert_busy_timeout_max_ms'=100. Ignoring 'async_insert_busy_timeout_min_ms' 2025.07.13 02:29:25.179798 [ 7056 ] {a2dfd622-1fa7-41c1-9377-c3b9a60b8771} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33492) (comment: 03302_merge_table_structure_unification.sql) (query 10, line 26) (in query: -- TODO: defaults are not calculated SELECT * FROM test_merge ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x000000002cc5424d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4170: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x000000002cc53ee0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4038: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc50b4a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc056cc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.184107 [ 7056 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x000000002cc5424d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4170: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x000000002cc53ee0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4038: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc50b4a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc056cc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.308651 [ 32979 ] {05bdc495-9e45-4ab3-92cb-e61cf49c4e08} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53686) (comment: 01825_new_type_json_3.gen.sql) (query 21, line 50) (in query: SELECT id, data.k1.k2, data.k1.k3 FROM t_json_3 ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.340723 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.501954 [ 34260 ] {b9636d28-21a9-4873-8c50-6a45a437f360} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53580) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 37, line 113) (in query: -- optimize_skip_unused_shards does not support non-constants select * from dist_01756 where dummy in (select * from system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.521891 [ 34260 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.522989 [ 6024 ] {3c702903-61d0-4c39-a6c8-fff8fd61d31b} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33482) (comment: 02968_adaptive_async_insert_timeout.sql) (query 7, line 35) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_increase_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:610: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d4047e7 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d4019df 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d4014ef 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.536692 [ 6024 ] {} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:610: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d4047e7 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d4019df 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d4014ef 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.538285 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.548960 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.560098 [ 33000 ] {35948fe2-5d68-47dd-bbd2-4acd0147b7a6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1112, line 1112) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt16(1) as r FORMAT CSV;) 2025.07.13 02:29:25.568051 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:25.713171 [ 6024 ] {4bed59c5-2a1d-44c9-a315-7e475eea1e4a} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33482) (comment: 02968_adaptive_async_insert_timeout.sql) (query 8, line 43) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_decrease_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:613: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d404863 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d4019df 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d4014ef 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:25.725728 [ 6024 ] {} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:613: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d404863 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d4019df 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d4014ef 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ac428 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:26.081857 [ 33000 ] {90bd4a8f-84ee-40c6-b289-0228957caf0d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1117, line 1117) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) > N as r FORMAT CSV;) 2025.07.13 02:29:26.092380 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:26.732934 [ 33000 ] {d244d991-3829-4828-838a-0e674f042ac8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1122, line 1122) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt16(-1) as r FORMAT CSV;) 2025.07.13 02:29:26.752385 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:27.279984 [ 33000 ] {f7e8e9a8-e6fb-4f64-a588-bf7ebf9969c1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1127, line 1127) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) > N as r FORMAT CSV;) 2025.07.13 02:29:27.282983 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:27.895106 [ 33000 ] {70623ae8-16dd-4951-a067-9f8a3924c9b2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1132, line 1132) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt32(1) as r FORMAT CSV;) 2025.07.13 02:29:27.914029 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:28.849533 [ 33000 ] {1b00e9ed-cb10-4794-9202-619dada70fb5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1137, line 1137) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) > N as r FORMAT CSV;) 2025.07.13 02:29:28.854724 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:28.896168 [ 34277 ] {ea7a8f11-0b3a-4f8a-b8af-c71bb8d51413} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38096) (comment: 00398_url_functions.gen.sql) (query 171, line 189) (in query: SELECT cutQueryString('http://www.example.com:1234');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:28.912282 [ 34277 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:29.385828 [ 33000 ] {603f0e9d-d40d-46b7-9ad1-367a2ec59c5b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1142, line 1142) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt32(-1) as r FORMAT CSV;) 2025.07.13 02:29:29.388906 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:30.156438 [ 33000 ] {e870e181-2d1c-4917-b65e-61f13f02255b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1147, line 1147) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) > N as r FORMAT CSV;) 2025.07.13 02:29:30.168173 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:30.311260 [ 3462 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {484e62b1-1d07-479e-a9fa-d3fba3e9330c::19700126_38_181_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:30.336825 [ 2824 ] {fe217ea8-048a-4244-bd13-f5275fc60a79} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41732) (comment: 02943_order_by_all.sql) (query 5, line 16) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:29:30.358924 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:29:30.874935 [ 33000 ] {6ca23c1f-c929-4adc-b2b4-bfb869ce6163} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1152, line 1152) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt64(1) as r FORMAT CSV;) 2025.07.13 02:29:30.895460 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:31.253989 [ 34273 ] {d7d7bb49-ac3b-4855-9360-b8e72832da02} executeQuery: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 4.00 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41752) (comment: 01010_pmj_on_disk.sql) (query 4, line 13) (in query: SELECT n, j FROM (SELECT number AS n FROM numbers(4)) nums ANY LEFT JOIN ( SELECT number * 2 AS n, number + 10 AS j FROM numbers(4000) ) js2 USING n ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:767: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x000000002e45e4da 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002e45b5c2 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:31.277748 [ 34273 ] {} TCPHandler: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 4.00 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:767: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x000000002e45e4da 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002e45b5c2 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dd7f7a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:31.598143 [ 2824 ] {9cbd7d08-1c2b-4b7c-901e-f99842ac4cab} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary test_11.dict as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41768) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x0000000030388276 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb28b9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:29:31.617032 [ 2824 ] {} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary test_11.dict as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x0000000030388276 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb28b9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:29:31.628757 [ 33000 ] {5cd0d01d-be72-48c1-b883-7bd027eff175} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1157, line 1157) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) > N as r FORMAT CSV;) 2025.07.13 02:29:31.649922 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:31.698937 [ 2824 ] {c3d2e634-b20c-405e-861b-5bfba95b0b1f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41768) (comment: 01225_drop_dictionary_as_table.sql) (query 5, line 15) (in query: DROP DICTIONARY dict;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:29:31.726397 [ 2824 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:29:32.425151 [ 33000 ] {4c4e6b93-42a5-421c-b2c4-e2cc3988c790} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1162, line 1162) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt64(-1) as r FORMAT CSV;) 2025.07.13 02:29:32.441971 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:33.153365 [ 33000 ] {5d25b1a4-61a1-4cb6-b523-f6041a707bcf} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1167, line 1167) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) > N as r FORMAT CSV;) 2025.07.13 02:29:33.158225 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:33.521658 [ 33000 ] {b067dce6-fe5c-45a1-9683-95d12151a068} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1172, line 1172) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt8(1) as r FORMAT CSV;) 2025.07.13 02:29:33.547037 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:34.224053 [ 33000 ] {b2bdca0c-4cd6-459f-8694-ce103ed9b461} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1177, line 1177) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) >= N as r FORMAT CSV;) 2025.07.13 02:29:34.241885 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:35.148443 [ 33000 ] {00b9ee06-68c9-4fd7-85ba-8f3dcca5a1af} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1182, line 1182) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt8(-1) as r FORMAT CSV;) 2025.07.13 02:29:35.157730 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:35.726028 [ 33000 ] {0f1f68d6-16df-4232-9dff-a2a9d9853d58} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1187, line 1187) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) >= N as r FORMAT CSV;) 2025.07.13 02:29:35.750144 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:36.128093 [ 46285 ] {3063c853-cd54-4c06-8a2f-5279f0bc64e1} executeQuery: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49082) (comment: 03165_storage_merge_view_prewhere.sql) (query 12, line 34) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`whatever` AS `whatever` FROM `test_11`.`ids` AS `__table1` ALL INNER JOIN view(SELECT * FROM merge(currentDatabase(), 'data*')) AS `__table2` ON `__table1`.`id` = `__table2`.`id` WHERE `__table2`.`status` IN ['CREATED', 'CREATING'] ORDER BY `__table2`.`event_time` DESC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 2025.07.13 02:29:36.136120 [ 2823 ] {a3e73efb-1344-46d2-b6a1-9b484ee22863} executeQuery: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56482) (comment: 03165_storage_merge_view_prewhere.sql) (query 12, line 34) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`whatever` AS `whatever` FROM `test_11`.`ids` AS `__table1` ALL INNER JOIN view(SELECT * FROM merge(currentDatabase(), 'data*')) AS `__table2` ON `__table1`.`id` = `__table2`.`id` WHERE `__table2`.`status` IN ['CREATED', 'CREATING'] ORDER BY `__table2`.`event_time` DESC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 2025.07.13 02:29:36.136547 [ 3816 ] {7234ac22-21fe-467c-8168-2866309a6758} executeQuery: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57066) (comment: 03165_storage_merge_view_prewhere.sql) (query 12, line 34) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`whatever` AS `whatever` FROM `test_11`.`ids` AS `__table1` ALL INNER JOIN view(SELECT * FROM merge(currentDatabase(), 'data*')) AS `__table2` ON `__table1`.`id` = `__table2`.`id` WHERE `__table2`.`status` IN ['CREATED', 'CREATING'] ORDER BY `__table2`.`event_time` DESC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 2025.07.13 02:29:36.142327 [ 46285 ] {} TCPHandler: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 2025.07.13 02:29:36.143095 [ 3816 ] {} TCPHandler: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 2025.07.13 02:29:36.146801 [ 2823 ] {} TCPHandler: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 2025.07.13 02:29:36.159290 [ 2824 ] {322736db-4503-4285-b4ae-8c5128f05b8d} executeQuery: Code: 636. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 : While executing Remote. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41776) (comment: 03165_storage_merge_view_prewhere.sql) (query 12, line 34) (in query: SELECT id, whatever FROM ids AS l INNER JOIN view(SELECT * FROM merge(currentDatabase(), 'data*')) AS s ON l.id = s.id WHERE (status IN ['CREATED', 'CREATING']) ORDER BY event_time DESC ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:29:36.193947 [ 2824 ] {} TCPHandler: Code: 636. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000030509753 6. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003050a0f1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848c0d5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002848be88 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002848a631 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002ccb0cd5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002ccb0a96 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f438 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 22. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:59: DB::TableFunctionView::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002b3ca3f6 23. ./build_docker/./src/TableFunctions/TableFunctionView.cpp:69: DB::TableFunctionView::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002b3cab32 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 25. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5e3b7 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 : While executing Remote. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:36.406557 [ 33000 ] {5a4297fd-8c51-48d2-b357-610b372cc860} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1192, line 1192) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt16(1) as r FORMAT CSV;) 2025.07.13 02:29:36.416995 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:37.204647 [ 33000 ] {61bcea28-3fc3-4845-85f5-8fe943a396df} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1197, line 1197) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) >= N as r FORMAT CSV;) 2025.07.13 02:29:37.215883 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:37.720114 [ 6024 ] {3be5c2c7-e496-4c5a-a021-01b8172b85b2} executeQuery: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41788) (comment: 02864_statistics_bug_67742.sql) (query 12, line 14) (in query: SELECT count(*) FROM tab WHERE a < '10.5';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0d0d28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b50d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc9e1f 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003211638f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd49d49 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd841aa 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a6ab 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 24. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 27. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 28. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:29:37.723938 [ 6024 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0d0d28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b50d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc9e1f 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003211638f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd49d49 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd841aa 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a6ab 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 24. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 27. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 28. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:29:37.899323 [ 33000 ] {f3c3a03b-d547-4206-b6d6-eb250d000a0f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1202, line 1202) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt16(-1) as r FORMAT CSV;) 2025.07.13 02:29:37.901844 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:38.579514 [ 33000 ] {572ee9d8-5768-487e-b464-110df133a1ff} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1207, line 1207) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) >= N as r FORMAT CSV;) 2025.07.13 02:29:38.582354 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:38.934381 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:38.935056 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:38.968932 [ 5379 ] {b9bce3f2-1e99-49b5-8651-b02e0474a4cc} executeQuery: Code: 516. DB::Exception: Received from 127.0.0.1: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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/118/118ee56f-5c3b-4fb5-8c65-8989632a6e1c/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41830) (comment: 01555_system_distribution_queue_mask.sql) (query 10, line 19) (in query: -- since test_cluster_with_incorrect_pw contains incorrect password ignore error system flush distributed dist_01555;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:396: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a994ce 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 18. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:29:39.085017 [ 33000 ] {17fab808-0783-4f92-87d3-eccfe30ae87d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1212, line 1212) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt32(1) as r FORMAT CSV;) 2025.07.13 02:29:39.088560 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:39.120295 [ 5379 ] {} TCPHandler: Code: 516. DB::Exception: Received from 127.0.0.1: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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/118/118ee56f-5c3b-4fb5-8c65-8989632a6e1c/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:396: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a994ce 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 18. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000303b5d5a 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000002e30dcac 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6fd7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:29:39.388823 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:39.389470 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:39.459807 [ 5379 ] {e89a5d2b-2f9c-47e6-96c2-c28d61826c01} StorageDistributed (dist_01555): Cannot flush: Code: 516. DB::Exception: Received from 127.0.0.1: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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/118/118ee56f-5c3b-4fb5-8c65-8989632a6e1c/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a9945e 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 18. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1728: DB::StorageDistributed::flushAndPrepareForShutdown() @ 0x00000000303b3607 7. ./src/Storages/IStorage.h:565: DB::IStorage::flushAndShutdown(bool) @ 0x000000002dcba6bb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:302: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2c3c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:39.529858 [ 33000 ] {f7eae1a4-8a45-4373-9d7d-2c70727fefbe} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1217, line 1217) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) >= N as r FORMAT CSV;) 2025.07.13 02:29:39.556762 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:39.998747 [ 10341 ] {9b8457cd-a6c9-49c9-9727-58a08c3a181a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33456) (comment: 01079_order_by_pk.sql) (query 3, line 5) (in query: SELECT x FROM mt_pk ORDER BY x ASC LIMIT 10000000, 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:29:40.086592 [ 10341 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:40.093010 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.112790 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.119373 [ 3391 ] {} test_9.dist_01555.DistributedInsertQueue.default: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/3b2/3b20fd2a-8ed6-4ee2-b2a7-b2e2f9bf7226/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:396: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a9956c 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x0000000030a99c19 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.139255 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.140437 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.142555 [ 5379 ] {f22e4464-13e6-43c1-856e-f9ae7d3edbec} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/3b2/3b20fd2a-8ed6-4ee2-b2a7-b2e2f9bf7226/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41830) (comment: 01555_system_distribution_queue_mask.sql) (query 16, line 32) (in query: -- since test_cluster_with_incorrect_pw contains incorrect password ignore error system flush distributed dist_01555;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a9945e 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 18. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:29:40.147057 [ 5379 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/3b2/3b20fd2a-8ed6-4ee2-b2a7-b2e2f9bf7226/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a9945e 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 18. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000303b5d5a 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000002e30dcac 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6fd7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:29:40.250159 [ 33000 ] {4d5b1ac2-5e44-41a9-8c87-158459519be7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1222, line 1222) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt32(-1) as r FORMAT CSV;) 2025.07.13 02:29:40.261067 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:40.329080 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.329817 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.355788 [ 3392 ] {} test_9.dist_01555.DistributedInsertQueue.default: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/3b2/3b20fd2a-8ed6-4ee2-b2a7-b2e2f9bf7226/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a9945e 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x0000000030a99c19 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.458566 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.459157 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.460234 [ 5379 ] {8db05868-90a8-4e5f-8427-8090f70c024b} StorageDistributed (dist_01555): Cannot flush: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 : While sending /var/lib/clickhouse/store/3b2/3b20fd2a-8ed6-4ee2-b2a7-b2e2f9bf7226/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000314835eb 6. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003147e265 7. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000314882cd 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314addd9 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:273: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000314bfce7 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:178: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl[abi:ne190107]::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000314c11e1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000314c244e 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000314bf211 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000314bf972 14. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x0000000030a9fb83 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a9945e 16. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 18. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1728: DB::StorageDistributed::flushAndPrepareForShutdown() @ 0x00000000303b3607 7. ./src/Storages/IStorage.h:565: DB::IStorage::flushAndShutdown(bool) @ 0x000000002dcba6bb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:302: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2c3c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:40.909444 [ 33000 ] {c0fbb39e-5933-4e7f-bf0c-3df2386cbf21} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1227, line 1227) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) >= N as r FORMAT CSV;) 2025.07.13 02:29:40.912669 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:41.222376 [ 46282 ] {ecd34e99-f88a-41e7-b29a-12b7db862d82} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=848). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45090) (comment: 00978_sum_map_bugfix.sql) (query 5, line 5) (in query: select number, arrayReduce( 'max', [a] ) from (select materialize([100,100,200]) a, number from numbers(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:41.253686 [ 46282 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=848). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:41.320736 [ 33000 ] {78347ff9-e308-4ab2-83fc-b7af61e6e16d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1232, line 1232) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt64(1) as r FORMAT CSV;) 2025.07.13 02:29:41.323524 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:41.373184 [ 5072 ] {39fb957b-8335-4a86-82e7-4853dacffc2f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45068) (comment: 00224_shard_distributed_aggregation_memory_efficient_and_overflows.sql) (query 5, line 14) (in query: SELECT count() = 200000 FROM remote('127.0.0.{2,3}', currentDatabase(), numbers_100k_log) GROUP BY number WITH TOTALS ORDER BY number LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2afe46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:41.396879 [ 5072 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2afe46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:42.031571 [ 33000 ] {f724d57a-6428-48e6-ae4f-1b97afe9b3ff} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1237, line 1237) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) >= N as r FORMAT CSV;) 2025.07.13 02:29:42.039013 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:42.755450 [ 33000 ] {02896a05-1630-4b93-915f-9a036698f11b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1242, line 1242) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt64(-1) as r FORMAT CSV;) 2025.07.13 02:29:42.776901 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:43.290393 [ 33000 ] {08aedbe7-7088-4b7b-aa03-ccbc2514b112} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58566) (comment: 00921_datetime64_compatibility_long.sh) (query 1247, line 1247) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) >= N as r FORMAT CSV;) 2025.07.13 02:29:43.293739 [ 33000 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:29:43.925665 [ 4694 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:44.788549 [ 3885 ] {fe337027-064d-4406-8a7a-c4d85c049496} executeQuery: Code: 57. DB::Exception: Table test_xh3i73eh.mt already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45182) (comment: 01293_optimize_final_force.sh) (query 2, line 3) (in query: CREATE TABLE mt (`x` UInt8, `k` UInt8 DEFAULT 0) ENGINE = SummingMergeTree ORDER BY k SETTINGS index_granularity = 44541, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 274794390, compact_parts_max_granules_to_buffer = 122, compact_parts_merge_max_bytes_to_prefetch_part = 27549678, merge_max_block_size = 6077, 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 = 7442887698, index_granularity_bytes = 15743315, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 43028, primary_key_compress_block_size = 94031, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:44.824052 [ 3885 ] {} TCPHandler: Code: 57. DB::Exception: Table test_xh3i73eh.mt already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:29:51.916344 [ 5382 ] {3505bb4a-4d83-44d3-bd44-10480c743296} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract('100-200'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 43, line 50) (in query: select regexpExtract('100-200');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x000000002063371b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:29:51.940210 [ 5382 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract('100-200'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x000000002063371b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:29:51.960101 [ 46294 ] {a9c966fc-5236-49cc-86e2-67a9cef32548} executeQuery: Code: 44. DB::Exception: Column of type FixedString is not supported by soundex function: In scope SELECT soundex(toFixedString('Smith', 5)). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45244) (comment: 02711_soundex_function.sql) (query 20, line 26) (in query: -- negative tests SELECT soundex(toFixedString('Smith', 5));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::SoundexImpl::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000020864aee 6. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020864286 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:29:51.962595 [ 46294 ] {} TCPHandler: Code: 44. DB::Exception: Column of type FixedString is not supported by soundex function: In scope SELECT soundex(toFixedString('Smith', 5)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::SoundexImpl::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000020864aee 6. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020864286 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:29:52.044332 [ 5382 ] {df340c69-7e47-4306-996e-44595e8dfd6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 4: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 44, line 51) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', 1, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x000000002063371b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:29:52.048687 [ 46294 ] {9058eb91-f933-408e-8386-b3e1b60ee991} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function soundex: In scope SELECT soundex(5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45244) (comment: 02711_soundex_function.sql) (query 21, line 28) (in query: SELECT soundex(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020864693 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:29:52.050411 [ 5382 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 4: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x000000002063371b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:29:52.068239 [ 46294 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function soundex: In scope SELECT soundex(5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020864693 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:29:52.330652 [ 5382 ] {bb5758bd-a1e5-4dda-90c6-17d502029217} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: FixedString(10): In scope SELECT regexpExtract(CAST('100-200', 'FixedString(10)'), '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 45, line 52) (in query: select regexpExtract(cast('100-200' as FixedString(10)), '(\\d+)-(\\d+)', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.350962 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: FixedString(10): In scope SELECT regexpExtract(CAST('100-200', 'FixedString(10)'), '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.406323 [ 2846 ] {} RefreshTask: test_9m795vjx.c: Refresh failed (attempt 1/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.src' in scope SELECT * FROM test_9m795vjx.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000304e43fd 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000031406128 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:52.442545 [ 7220 ] {} test_xh3i73eh.mt (18dc9e11-8237-4d1c-a0e2-628c16eb9c79): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:29:52.475301 [ 7220 ] {} DatabaseCatalog: Cannot drop table test_xh3i73eh.mt (18dc9e11-8237-4d1c-a0e2-628c16eb9c79). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:52.552049 [ 5382 ] {79457276-9980-4cbf-b684-9a1234a26476} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'pattern' to function 'regexpExtract'. Expected: const String, got: FixedString(20): In scope SELECT regexpExtract('100-200', CAST('(\\d+)-(\\d+)', 'FixedString(20)'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 46, line 53) (in query: select regexpExtract('100-200', cast('(\\d+)-(\\d+)' as FixedString(20)), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.581177 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'pattern' to function 'regexpExtract'. Expected: const String, got: FixedString(20): In scope SELECT regexpExtract('100-200', CAST('(\\d+)-(\\d+)', 'FixedString(20)'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.653411 [ 3330 ] {} RefreshTask: test_9m795vjx.c: Refresh failed (attempt 2/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.src' in scope SELECT * FROM test_9m795vjx.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000304e43fd 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000031406128 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:52.663020 [ 3450 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9e9d30c2-ddc4-4091-b2ec-01a4dddb2629::all_1_51_10}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:52.707807 [ 5382 ] {e2f7b57a-9a49-4966-a7a8-d5181814f940} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'index' to function 'regexpExtract'. Expected: Integer, got: String: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 47, line 54) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', 'a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.740531 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'index' to function 'regexpExtract'. Expected: Integer, got: String: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.834530 [ 5382 ] {63540f20-21ca-42be-a6bf-a19eca43786e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: UInt8: In scope SELECT regexpExtract(100, '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 48, line 55) (in query: select regexpExtract(100, '(\\d+)-(\\d+)', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.839237 [ 2876 ] {} RefreshTask: test_9m795vjx.c: Refresh failed (attempt 3/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.src' in scope SELECT * FROM test_9m795vjx.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000304e43fd 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000031406128 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:52.846178 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: UInt8: In scope SELECT regexpExtract(100, '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:52.997445 [ 5382 ] {2212fcbe-76d0-41bc-a6d7-e84c7037a54f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'pattern' to function 'regexpExtract'. Expected: const String, got: UInt8: In scope SELECT regexpExtract('100-200', 1, 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 49, line 56) (in query: select regexpExtract('100-200', 1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:53.014677 [ 5382 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'pattern' to function 'regexpExtract'. Expected: const String, got: UInt8: In scope SELECT regexpExtract('100-200', 1, 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:53.263223 [ 5382 ] {ec0fc202-4134-41a9-b4d8-547cda3035a6} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'pattern' to function 'regexpExtract'. Expected: const String, got: String: In scope SELECT regexpExtract('100-200', materialize('(\\d+)-(\\d+)'), 1). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 50, line 57) (in query: select regexpExtract('100-200', materialize('(\\d+)-(\\d+)'), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:53.280329 [ 5382 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'pattern' to function 'regexpExtract'. Expected: const String, got: String: In scope SELECT regexpExtract('100-200', materialize('(\\d+)-(\\d+)'), 1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020633556 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:53.346706 [ 2832 ] {} RefreshTask: test_9m795vjx.c: Refresh failed (attempt 1/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.src' in scope SELECT * FROM test_9m795vjx.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000304e43fd 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000031406128 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:53.444379 [ 5382 ] {6a12cac2-fca3-424f-90ac-bf2829ee7f1e} executeQuery: Code: 353. DB::Exception: Index value 3 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 3). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 51, line 58) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x0000000020633baf 5. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206328b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:29:53.463354 [ 5382 ] {} TCPHandler: Code: 353. DB::Exception: Index value 3 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 3). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x0000000020633baf 5. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206328b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:29:53.485566 [ 2842 ] {} RefreshTask: test_9m795vjx.c: Refresh failed (attempt 2/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.src' in scope SELECT * FROM test_9m795vjx.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000304e43fd 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000031406128 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:53.593022 [ 5382 ] {0dda26de-704a-4aee-9426-c511b7ac8799} executeQuery: Code: 353. DB::Exception: Index value -1 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', -1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 52, line 59) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x0000000020633baf 5. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206328b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:29:53.610736 [ 5382 ] {} TCPHandler: Code: 353. DB::Exception: Index value -1 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', -1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x0000000020633baf 5. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206328b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:29:53.724703 [ 2879 ] {} RefreshTask: test_9m795vjx.c: Refresh failed (attempt 3/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.src' in scope SELECT * FROM test_9m795vjx.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000304e43fd 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000031406128 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:54.081822 [ 5382 ] {b9ee7396-a419-470c-b3d0-5a3c1428569a} executeQuery: Code: 353. DB::Exception: Index value 1 for regexp pattern `\d+-\d+` in function regexpExtract is out-of-range, should be in [0, 1): In scope SELECT regexpExtract('100-200', '\\d+-\\d+', 1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45126) (comment: 02562_regexp_extract.sql) (query 54, line 61) (in query: select regexpExtract('100-200', '\\d+-\\d+', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x0000000020633baf 5. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206328b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:29:54.089549 [ 5382 ] {} TCPHandler: Code: 353. DB::Exception: Index value 1 for regexp pattern `\d+-\d+` in function regexpExtract is out-of-range, should be in [0, 1): In scope SELECT regexpExtract('100-200', '\\d+-\\d+', 1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x0000000020633baf 5. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206328b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:29:55.820386 [ 5826 ] {ed17590d-1d63-4eea-8873-2d858bc07122} PushingToViews: Failed to push block to view test_13.view (6b8a7bfb-a964-43df-9e81-389b4a564333), Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp'] 2025.07.13 02:29:55.836569 [ 5826 ] {ed17590d-1d63-4eea-8873-2d858bc07122} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48950) (comment: 01913_join_push_down_bug.sql) (query 3, line 14) (in query: INSERT INTO test VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:29:55.862297 [ 5826 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:29:58.782445 [ 3885 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:59.344737 [ 4938 ] {0a03fd70-4204-40e3-9697-4e15f8a90bb4} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_15517130442449766950_12589308372858479765 :: 1) -> nullIn(__table1.str, __set_15517130442449766950_12589308372858479765) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48982) (comment: 01681_bloom_filter_nullable_column.sql) (query 9, line 23) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000017e02a6f 5. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::checkColumnsNumber(unsigned long) const @ 0x000000002df5716f 6. ./build_docker/./src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002df563ca 7. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001c1ea170 8. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c1e9710 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d63305e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f51e99 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f9af 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:59.353846 [ 4938 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_15517130442449766950_12589308372858479765 :: 1) -> nullIn(__table1.str, __set_15517130442449766950_12589308372858479765) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000017e02a6f 5. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::checkColumnsNumber(unsigned long) const @ 0x000000002df5716f 6. ./build_docker/./src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002df563ca 7. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001c1ea170 8. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c1e9710 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d63305e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f51e99 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f9af 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:29:59.930129 [ 4938 ] {f2baca06-1938-43a6-9584-df83f7f72de3} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_15517130442449766950_12589308372858479765 :: 1) -> nullIn(__table1.str, __set_15517130442449766950_12589308372858479765) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48982) (comment: 01681_bloom_filter_nullable_column.sql) (query 10, line 26) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000017e02a6f 5. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::checkColumnsNumber(unsigned long) const @ 0x000000002df5716f 6. ./build_docker/./src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002df563ca 7. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001c1ea170 8. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c1e9710 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d63305e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f51e99 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f9af 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:29:59.953707 [ 4938 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_15517130442449766950_12589308372858479765 :: 1) -> nullIn(__table1.str, __set_15517130442449766950_12589308372858479765) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000017e02a6f 5. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::checkColumnsNumber(unsigned long) const @ 0x000000002df5716f 6. ./build_docker/./src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002df563ca 7. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001c1ea170 8. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c1e9710 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d63305e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000030f51e99 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000030f80547 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f9af 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 31. ? @ 0x00007f9c53164ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:00.008605 [ 5826 ] {a49deac6-e6f4-4446-bccd-95590a1fa0be} executeQuery: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 1, line 1) (in query: SELECT extractGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70afb 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:00.032291 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70afb 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:00.462227 [ 5826 ] {9e94a5c5-fc89-4702-987c-67abe8b5da43} executeQuery: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 2, line 2) (in query: SELECT extractAllGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6ee3d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:00.533997 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6ee3d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:00.685142 [ 5826 ] {4f6bbc3f-ed77-404e-beba-c18e24eb53af} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 3, line 4) (in query: SELECT extractGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70b95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:00.709761 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70b95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:00.949727 [ 5826 ] {3e3a7ebb-3420-4235-a3b8-ca49050ef859} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 4, line 5) (in query: SELECT extractAllGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6eed5 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:00.975509 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6eed5 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.191589 [ 5826 ] {692aad1f-a199-45e6-ab56-a586e951b74a} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 5, line 7) (in query: SELECT extractGroups('hello', '\0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70b95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:01.225502 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70b95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:01.344694 [ 46282 ] {3f402fc6-3537-4a3f-93f2-64fd2708b8dc} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48928) (comment: 00203_full_join.sql) (query 22, line 29) (in query: SELECT k1, k2, k3, val_t1, val_t2 FROM t1_00203 ANY FULL JOIN t2_00203 USING (k3, k1, k2) ORDER BY k1, k2, k3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:997: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbb77b1 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbac8dc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:01.347232 [ 46282 ] {} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:997: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbb77b1 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbac8dc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:01.400251 [ 5826 ] {515bdf55-42ee-48d5-9d41-bc3270d18e78} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 6, line 8) (in query: SELECT extractAllGroups('hello', '\0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6eed5 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.423831 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6eed5 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.520182 [ 46286 ] {597ac918-263b-4420-9f7f-d9266d98796d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47458) (comment: 01042_h3_k_ring.sql) (query 3, line 5) (in query: SELECT h3kRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:01.553051 [ 46286 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:01.569540 [ 5826 ] {3ac1f458-5eda-40d1-892c-674d8f0484f1} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 7, line 10) (in query: SELECT extractGroups('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70b95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:01.578263 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70b95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:01.660759 [ 5826 ] {3a509892-1399-445b-88a9-2c45f057da47} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 8, line 11) (in query: SELECT extractAllGroups('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6eed5 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.692302 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6eed5 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.712357 [ 46286 ] {2eca1842-98a7-4045-a1cd-1d8c84f46235} executeQuery: Code: 12. DB::Exception: Too large 'k' argument for h3kRing function, maximum 10000: In scope SELECT h3kRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47458) (comment: 01042_h3_k_ring.sql) (query 4, line 6) (in query: SELECT h3kRing(581276613233082367, toUInt16(-1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001c164faf 5. DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c183ab2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.734494 [ 46286 ] {} TCPHandler: Code: 12. DB::Exception: Too large 'k' argument for h3kRing function, maximum 10000: In scope SELECT h3kRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001c164faf 5. DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c183ab2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:01.905391 [ 5826 ] {29df4cf2-5943-4a20-8d3f-e14116910aa8} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 9, line 13) (in query: SELECT extractGroups('hello', 'hello|world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70c35 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:01.921309 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad70c35 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:30:02.139021 [ 5826 ] {1b063198-c735-4db8-bdfd-eea7c2ea391a} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47438) (comment: 01275_extract_groups_check.sql) (query 10, line 14) (in query: SELECT extractAllGroups('hello', 'hello|world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6ef75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:02.171316 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6ef75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:02.189449 [ 46286 ] {98442b47-e218-4ef6-a322-c4e5c38f1204} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47458) (comment: 01042_h3_k_ring.sql) (query 7, line 10) (in query: SELECT h3kRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:02.203396 [ 46286 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa6f2f 5. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c18479e 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:02.294598 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:03.565588 [ 34277 ] {641a9897-b202-4d52-84d4-0fb5bed78527} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter12652196198309240136, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47512) (comment: 01258_wrong_cast_filimonov.sql) (query 1, line 1) (in query: CREATE TABLE x (`id` UInt64, `t` AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) DEFAULT arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)])) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 31889, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.24760854244232178, replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 115924197, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1405755, merge_max_block_size = 12922, old_parts_lifetime = 205., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24516786, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 98233, primary_key_compress_block_size = 53529, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb18647 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 19. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f354d 20. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:30:03.572429 [ 34277 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter12652196198309240136, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002ad87fb2 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad827e7 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad64e2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad62f8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad61f23 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb19213 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb18647 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d69d5fd 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002d6b02bf 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6a3cbd 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 19. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f354d 20. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:30:04.095007 [ 6126 ] {85ab1d3f-c58f-4ac3-9162-770f8696460b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47532) (comment: 01825_type_json_distributed.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:04.137728 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:05.968219 [ 5826 ] {c2d9ba6c-5c5c-4304-8d5c-01dabdd12a4c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47488) (comment: 03122_analyzer_collate_in_window_function.sql) (query 6, line 9) (in query: select c2, groupArray(c2) over (partition by c1 order by c2 asc collate 'zh_Hans_CN') as res from test_window_collate order by c2 asc collate 'zh_Hans_CN';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:30:05.997428 [ 5826 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: 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) @ 0x0000000030e2b1be 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: 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) @ 0x00000000321af041 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321b7373 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9db9 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:30:06.571662 [ 5476 ] {c0eebc90-166f-4f46-95d5-b37d56023561} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 62543.786861 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36790) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:06.587843 [ 5476 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 62543.786861 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:30:06.691744 [ 5826 ] {8a727505-8388-4163-9f55-b3e33281113b} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47564) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:30:06.728774 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:30:07.768552 [ 3460 ] {428a6cde-b6ae-4c55-a5db-a473713db4ae::1_1_1_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:07.807796 [ 3460 ] {428a6cde-b6ae-4c55-a5db-a473713db4ae::1_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:07.809141 [ 3460 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {428a6cde-b6ae-4c55-a5db-a473713db4ae::1_1_1_0_4}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:08.148886 [ 6126 ] {88dcc254-db98-4a6e-b417-c76ce8f3a72d} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_4.txt' with part '1_1_1_0_3' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c5d4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47558) (comment: 03221_mutation_analyzer_skip_part.sh) (query 7, line 13) (in query: ALTER TABLE t_mutate_skip_part DELETE WHERE key = 2 AND v2 % 10 = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000030f0c797 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c636 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:08.206839 [ 6126 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_4.txt' with part '1_1_1_0_3' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c5d4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000030f0c797 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c636 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:09.698392 [ 2824 ] {f0e0143b-bfc6-4f35-aef5-606424942468} StorageDistributed (tt6): Name of remote database is empty. Default database will be used implicitly. 2025.07.13 02:30:09.944782 [ 2824 ] {c357f9a3-e7ee-4c3a-9c39-533bf639ec52} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_7.tt7', because it will lead to cyclic dependencies: test_7.tt6 -> [test_7.tt7]; test_7.tt7 -> [test_7.tt6]. (INFINITE_LOOP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34352) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: 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 @ 0x000000002d608f87 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d608c64 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dc9017a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1911: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88775 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:09.997698 [ 2824 ] {} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_7.tt7', because it will lead to cyclic dependencies: test_7.tt6 -> [test_7.tt7]; test_7.tt7 -> [test_7.tt6]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: 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 @ 0x000000002d608f87 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d608c64 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dc9017a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1911: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88775 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:10.312196 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:10.594624 [ 5826 ] {0a067076-427a-4427-8404-16fbbc2fba7b} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47590) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:10.605104 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:10.812805 [ 5826 ] {059e3e25-47d3-42cb-840f-849067e6324a} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47590) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:10.820746 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:12.080581 [ 3885 ] {4dad6662-a3a6-4afb-800c-5a0f4e9ea201} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 10003.766902 ms, maximum: 10000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35842) (comment: 01249_flush_interactive.sh) (in query: SELECT DISTINCT number % 5 FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:12.085136 [ 3885 ] {4dad6662-a3a6-4afb-800c-5a0f4e9ea201} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 10003.766902 ms, maximum: 10000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:12.113454 [ 3885 ] {4dad6662-a3a6-4afb-800c-5a0f4e9ea201} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:35842). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. ./src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x00000000317068c3 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:145: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003170145e 7. DB::WriteBuffer::next() @ 0x0000000017cd6383 8. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:353: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003170400f 9. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000315c3822 10. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c7c3e 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:12.184265 [ 5826 ] {99e11172-4a37-439c-841e-84386519c004} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47590) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:12.188842 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:12.333663 [ 5826 ] {61d8b847-7885-4c7e-b569-1df7b19dc7e0} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47590) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:12.337382 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:12.651485 [ 3452 ] {696fb164-bcdd-487d-b952-21abbcdbb4a6::all_1_1_0_26} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:12.653281 [ 3452 ] {696fb164-bcdd-487d-b952-21abbcdbb4a6::all_1_1_0_26} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:12.657467 [ 3452 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {696fb164-bcdd-487d-b952-21abbcdbb4a6::all_1_1_0_26}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:13.280861 [ 5826 ] {3907e93f-5cf7-4512-8ab9-bacb95bfe5e1} executeQuery: Code: 57. DB::Exception: Table test_11.dist_01072 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47590) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 27, line 35) (in query: create table dist_01072 (key Int, value LowCardinality(Int), str String) Engine=Distributed(test_cluster_two_shards, currentDatabase(), data_01072, key%2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:13.289835 [ 5826 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.dist_01072 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:14.965076 [ 3816 ] {15330337-e9a6-4289-8f91-a819ad852355} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34440) (comment: 02433_default_expression_operator_in.sql) (query 11, line 31) (in query: -- Ensure that a table name cannot be passed to IN as string literal create table test (n int, m default n in 'default.table_name') engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e264473 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6af55c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6add29 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d6944f9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6abd27 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d69f716 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f354d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:14.970940 [ 3816 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e264473 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6af55c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6add29 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d6944f9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6abd27 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d69f716 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f354d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:15.073223 [ 3816 ] {e7605478-5caa-403a-8055-4878de0cd695} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34440) (comment: 02433_default_expression_operator_in.sql) (query 12, line 33) (in query: create table test (n int, m default in(n, 'default.table_name')) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e264473 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6af55c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6add29 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d6944f9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6abd27 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d69f716 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f354d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:15.084833 [ 3816 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e264473 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6af55c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6add29 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d6944f9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6abd27 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d69f716 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302f354d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302f3fb0 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66b4e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:15.573662 [ 3816 ] {46f871ae-64b9-43e9-9c3a-a2934d21bc03} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_13.id_join (8ea75de4-6c58-4f53-8e47-d551fcd1c211), because some tables depend on it: test_13.dep2. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34440) (comment: 02433_default_expression_operator_in.sql) (query 15, line 37) (in query: DROP TABLE id_join;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:15.585258 [ 3816 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_13.id_join (8ea75de4-6c58-4f53-8e47-d551fcd1c211), because some tables depend on it: test_13.dep2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d61568f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d6086e4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d608bb6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2bd3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:16.428474 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:19.433884 [ 3816 ] {b1ff6ce6-eaed-4d10-a610-11e9de22d8a1} executeQuery: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34552) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (query 11, line 19) (in query: select * from dist_01319 where key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000002dd708f9 12. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:49: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x00000000320f52b6 13. ./build_docker/./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 @ 0x000000002f9e743e 14. ./build_docker/./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) @ 0x000000002f9e5695 15. ./build_docker/./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)>) @ 0x000000002f9e76b4 16. ./build_docker/./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) @ 0x000000002f9d04ae 17. ./build_docker/./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) @ 0x000000003039cf73 18. ./build_docker/./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) @ 0x000000002ddac77e 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 20. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:19.440015 [ 3816 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000030396e5b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030394c27 7. ./build_docker/./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) @ 0x000000002ddac4f6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000002dd708f9 12. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:49: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x00000000320f52b6 13. ./build_docker/./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 @ 0x000000002f9e743e 14. ./build_docker/./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) @ 0x000000002f9e5695 15. ./build_docker/./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)>) @ 0x000000002f9e76b4 16. ./build_docker/./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) @ 0x000000002f9d04ae 17. ./build_docker/./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) @ 0x000000003039cf73 18. ./build_docker/./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) @ 0x000000002ddac77e 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 20. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:20.666242 [ 3455 ] {63667ff6-b6f5-414a-9058-bdd20928b151::202507_1_111_22} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:20.751998 [ 3455 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {63667ff6-b6f5-414a-9058-bdd20928b151::202507_1_111_22}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:21.647670 [ 5379 ] {a756db1c-ec05-46d2-ab02-804995322919} executeQuery: Code: 36. DB::Exception: Expected two string literal arguments: zookeeper_path and replica_name. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42410) (comment: 01512_create_replicate_merge_tree_one_arg.sql) (query 1, line 3) (in query: CREATE TABLE mt (`v` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01497/mt') ORDER BY tuple() SETTINGS index_granularity = 56682, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 517753313, compact_parts_max_bytes_to_buffer = 473150820, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 21285100, merge_max_block_size = 16223, old_parts_lifetime = 346., 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 = 8378126472, index_granularity_bytes = 22514808, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 64, 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 = 99226, primary_key_compress_block_size = 78991, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:320: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&) @ 0x00000000311c0a1e 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:530: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c37d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:21.681196 [ 5379 ] {} TCPHandler: Code: 36. DB::Exception: Expected two string literal arguments: zookeeper_path and replica_name. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:320: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&) @ 0x00000000311c0a1e 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:530: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c37d8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:23.097471 [ 5382 ] {c131591a-22b8-4cdb-877d-a4f13985de79} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42478) (comment: 02287_type_object_convert.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:23.114333 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:24.839017 [ 3766 ] {da74d611-250e-4466-9612-7cd358c924b4} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42528) (comment: 01913_fix_column_transformer_replace_format.sql) (query 7, line 9) (in query: drop view my_view;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:30:24.885100 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:30:27.513503 [ 34277 ] {a50af557-0a80-41e3-9a07-03ebea6b8fb7} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02982_json_columns_with_metadata_http.sh) (in query: /* ddl_entry=query-0000000301 */ CREATE TABLE test_5.test UUID 'b7edc09e-245b-4791-b48b-7d47217fe86a' (`x` UInt32, `y` UInt32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:27.597152 [ 34277 ] {a50af557-0a80-41e3-9a07-03ebea6b8fb7} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42662) (comment: 02982_json_columns_with_metadata_http.sh) (query 1, line 1) (in query: create table test(x UInt32, y UInt32) engine=Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:27.604752 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:28.347970 [ 5826 ] {a92d43ae-ee2a-4a67-8485-e45103416389} executeQuery: Code: 36. DB::Exception: The maximum value for the input argument of function factorial is 20: In scope SELECT factorial(100). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42708) (comment: 02478_factorial.sql) (query 4, line 5) (in query: select factorial(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001ad790af 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001ad75a96 7. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001ad75326 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad74e53 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:30:28.382496 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: The maximum value for the input argument of function factorial is 20: In scope SELECT factorial(100). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001ad790af 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001ad75a96 7. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001ad75326 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad74e53 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:30:28.504963 [ 34277 ] {a595459f-f003-49ac-a959-8f689964ba52} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 5, line 2) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:28.515852 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:28.627141 [ 5826 ] {79763ab4-fd02-42eb-8c9a-1de94ac20c41} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function factorial: In scope SELECT factorial('100'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42708) (comment: 02478_factorial.sql) (query 5, line 6) (in query: select factorial('100');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001ad7f509 6. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001ad75189 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:28.652033 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function factorial: In scope SELECT factorial('100'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001ad7f509 6. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001ad75189 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:28.882071 [ 5826 ] {c6a13a37-694e-49ca-b5f6-9ba19fba2973} executeQuery: Code: 43. DB::Exception: Illegal type of argument of function factorial, should not be floating point or big int: In scope SELECT factorial(100.1234). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42708) (comment: 02478_factorial.sql) (query 6, line 7) (in query: select factorial(100.1234);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001ad7edc5 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001ad7869a 7. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001ad75666 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad74e53 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:30:28.966407 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of argument of function factorial, should not be floating point or big int: In scope SELECT factorial(100.1234). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001ad7edc5 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001ad7869a 7. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001ad75666 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad74e53 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:30:29.100915 [ 5476 ] {820bc8b5-4818-450a-8f6d-7b1a105a1dca} executeQuery: Code: 36. DB::Exception: Table test_9m795vjx.dest is already a target of another refreshable materialized view: test_9m795vjx.h. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42692) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:207: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000304dd3c1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304efb26 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304ef90a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000304ec72f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:30:29.136499 [ 5476 ] {} TCPHandler: Code: 36. DB::Exception: Table test_9m795vjx.dest is already a target of another refreshable materialized view: test_9m795vjx.h. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:207: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000304dd3c1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304efb26 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304ef90a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000304ec72f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:30:29.789066 [ 5826 ] {8535b722-dc94-437e-bece-82231b3061ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 1, line 4) (in query: -- incorrect number of arguments SELECT base64URLEncode();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:29.893864 [ 5826 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.048553 [ 5826 ] {107e1e0b-5ccf-47e8-93fa-17ca22db1b3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 2, line 6) (in query: SELECT base64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.054040 [ 5826 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.126421 [ 5826 ] {8b39a80f-3520-482b-b59b-7606a1f34150} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 3, line 7) (in query: SELECT tryBase64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.130434 [ 5826 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.291218 [ 5826 ] {cdeec1dd-78c4-4243-9fd3-09e1e0b8fac5} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 4, line 8) (in query: SELECT base64URLEncode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.296411 [ 5826 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.368206 [ 5826 ] {e578b009-6fee-4dc0-b61b-693d607f075a} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 5, line 9) (in query: SELECT base64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.383156 [ 5826 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.480476 [ 5826 ] {183f6f8f-bd1b-4e97-a353-e01b7a64b9ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 6, line 10) (in query: SELECT tryBase64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:30.485137 [ 5826 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:31.396320 [ 5826 ] {1e2567d9-8274-47eb-a5b3-7292d9628133} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 13, line 25) (in query: -- test with invalid inputs SELECT base64URLDecode('https://clickhouse.com');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f4e10d 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f4dc2c 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4cf9b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:30:31.401502 [ 5826 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f4e10d 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f4dc2c 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4cf9b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:30:31.611752 [ 5826 ] {d7b61826-74a3-476c-b52e-f45720fbd0b8} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 15, line 29) (in query: SELECT base64URLDecode('12?');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f4e10d 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f4dc2c 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4cf9b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:30:31.623104 [ 5826 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f4e10d 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f4dc2c 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4cf9b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:30:31.632403 [ 3337 ] {} RefreshTask: test_9m795vjx.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:31.903556 [ 5826 ] {a7e906a1-3cb6-44d0-a8b9-029eb7b859ab} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60258) (comment: 03167_base64_url_functions.sql) (query 17, line 31) (in query: SELECT base64URLDecode('aHR0cHM6Ly9jbGlja');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f4e10d 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f4dc2c 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4cf9b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:30:31.936685 [ 5826 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f48f0f 5. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f4e10d 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f4dc2c 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f4cf9b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:30:32.066680 [ 2906 ] {} RefreshTask: test_9m795vjx.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:32.100144 [ 4938 ] {535ac7fe-d8f6-4185-abde-b23485fe01df} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)). (REFRESH_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60348) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:286: DB::RefreshTask::wait()::$_0::operator()() const @ 0x00000000313febf9 6. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:296: DB::RefreshTask::wait() @ 0x00000000313fe27d 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:746: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6cbe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:32.144781 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)). (REFRESH_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:286: DB::RefreshTask::wait()::$_0::operator()() const @ 0x00000000313febf9 6. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:296: DB::RefreshTask::wait() @ 0x00000000313fe27d 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:746: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6cbe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:32.363800 [ 34277 ] {c20ee384-33bf-498e-98ae-925347f692b8} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 23, line 8) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:32.387418 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:32.459630 [ 2934 ] {} RefreshTask: test_9m795vjx.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:32.750664 [ 34277 ] {b75e86a1-53b5-4121-8dc1-607a942f52cf} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 26, line 9) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:32.775868 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:32.824961 [ 2928 ] {} RefreshTask: test_9m795vjx.h2: Refresh failed (attempt 4/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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:33.134158 [ 2993 ] {} RefreshTask: test_9m795vjx.h2: Refresh failed (attempt 5/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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000314067aa 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x00000000313ffc76 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:34.740004 [ 34277 ] {3ae2a363-f4e5-40b3-b500-d6f80e1e7c75} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 32, line 11) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:34.746933 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:35.066503 [ 5105 ] {} DynamicQueryHandler: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:35.808293 [ 29256 ] {2f54cc93-c720-4021-a77e-5a39fd026742} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60107.201003 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41804) (comment: 02455_one_row_from_csv_memory_usage.sh) (query 1, line 1) (in query: SELECT * FROM file('test_1ju69sra_10m_rows.csv.xz' , 'CSVWithNames') order by identifier, number, name, surname, birthday LIMIT 1 settings input_format_parallel_parsing=1, max_threads=1, max_parsing_threads=16, min_chunk_bytes_for_parallel_parsing=10485760, max_memory_usage=1000000000), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:35.837695 [ 29256 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60107.201003 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.272118 [ 4938 ] {257d6b7a-1f34-4533-a847-118892a75fb5} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02931_alter_materialized_view_query_inconsistent.sql) (in query: /* ddl_entry=query-0000000311 */ TRUNCATE TABLE IF EXISTS test_5.src), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.317782 [ 4938 ] {257d6b7a-1f34-4533-a847-118892a75fb5} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60358) (comment: 02931_alter_materialized_view_query_inconsistent.sql) (query 12, line 17) (in query: DROP TABLE IF EXISTS src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.321700 [ 4938 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.772807 [ 4938 ] {127cc77c-30d7-4dfb-8457-47fdccbc8fa1} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60452) (comment: 02833_window_func_range_offset.sql) (query 1, line 1) (in query: -- invalid start offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN 0.0 PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e240e02 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.810484 [ 4938 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e240e02 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.898629 [ 4938 ] {307584bf-3e0e-4ec4-a955-c6667436a71c} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60452) (comment: 02833_window_func_range_offset.sql) (query 2, line 3) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN nan PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e240e02 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:36.966473 [ 4938 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e240e02 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:37.210580 [ 4938 ] {3931c485-ba9f-4324-bb15-c9f6f158c4c7} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60452) (comment: 02833_window_func_range_offset.sql) (query 3, line 4) (in query: -- invalid end offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND 0.0 FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e240ec4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:37.219104 [ 4938 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e240ec4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:37.264347 [ 4938 ] {b678d6ef-6d4d-4bc7-a1ed-637dec67ca9c} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60452) (comment: 02833_window_func_range_offset.sql) (query 4, line 6) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND nan FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e240ec4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:37.276503 [ 4938 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e24146f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e240ec4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4f100 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc38372 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:37.756772 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:37.758062 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.116733 [ 4938 ] {339f7a94-da57-4970-b843-8e21931a04ce} executeQuery: Code: 60. DB::Exception: Table test_rn9row5l.ghdata does not exist. Maybe you meant test_11.data?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60512) (comment: 03271_ghdata_object_to_json_alter.sh) (query 1, line 1) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.135709 [ 4938 ] {} TCPHandler: Code: 60. DB::Exception: Table test_rn9row5l.ghdata does not exist. Maybe you meant test_11.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.480191 [ 46285 ] {fd054d49-dfcc-436f-ba47-36e91d6f450a} executeQuery: Code: 60. DB::Exception: Could not find table: ghdata. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60538) (comment: 03271_ghdata_object_to_json_alter.sh) (query 1, line 1) (in query: ALTER TABLE ghdata MODIFY column data JSON SETTINGS mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4dd74 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.494182 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4dd74 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.536850 [ 34277 ] {f58ac9fb-dce5-4965-8d98-3be630829b89} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 50, line 17) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.559558 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.871348 [ 3816 ] {5990b1c6-d55d-4ca0-979e-eedecc929b40} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37476) (comment: 03271_ghdata_object_to_json_alter.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:38.916245 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:39.018917 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:39.236218 [ 3816 ] {cdd24be8-fa26-4237-823c-7251f24243ef} 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.3.20372.altinityantalya (altinity build)) (from [::1]:37508) (comment: 03271_ghdata_object_to_json_alter.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:39.244024 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:39.639479 [ 3816 ] {6a93c89f-6d52-4d71-98c1-5ebc69678305} 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.3.20372.altinityantalya (altinity build)) (from [::1]:37512) (comment: 03271_ghdata_object_to_json_alter.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:39.658984 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:40.044163 [ 10341 ] {cf94f59b-c60f-4d38-aa59-002fe281d05f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:37516) (comment: 03271_ghdata_object_to_json_alter.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:40.056798 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:30:41.101845 [ 2823 ] {0f155355-ca7d-4547-a0d4-01bc14ab7bf7} executeQuery: Code: 48. DB::Exception: Adding or removing APPEND is not supported. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37564) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 2) (in query: alter table k modify refresh every 10 year;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:203: DB::RefreshTask::checkAlterIsPossible(DB::ASTRefreshStrategy const&) @ 0x00000000313fd2d8 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:677: DB::StorageMaterializedView::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000304e77a0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:30:41.120855 [ 2823 ] {} TCPHandler: Code: 48. DB::Exception: Adding or removing APPEND is not supported. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:203: DB::RefreshTask::checkAlterIsPossible(DB::ASTRefreshStrategy const&) @ 0x00000000313fd2d8 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:677: DB::StorageMaterializedView::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000304e77a0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:30:41.734111 [ 46285 ] {7a570f3a-9a49-4291-84f6-f3736c384ddd} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37558) (comment: 01714_alter_drop_version.sql) (query 4, line 14) (in query: ALTER TABLE alter_drop_version DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:41.768442 [ 46285 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd693c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:41.886187 [ 46285 ] {53a9db14-e8d9-449c-a9be-5ff3676e942c} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37558) (comment: 01714_alter_drop_version.sql) (query 5, line 15) (in query: ALTER TABLE alter_drop_version RENAME COLUMN ver TO rev;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:41.890626 [ 46285 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd687b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:43.071314 [ 34277 ] {4af3ae64-9216-4026-ac4a-bc86cd50ba04} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 74, line 25) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:43.101345 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:44.998182 [ 2823 ] {8e4cd658-b4d6-4b12-8f18-c89d7b236874} executeQuery: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37658) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 2) (in query: create materialized view n refresh every 1 second (x Int64) engine MergeTree as select 1 as x from numbers(2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311ce6af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311cb345 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:297: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000304db7a4 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304efb26 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304ef90a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000304ec72f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:30:45.026977 [ 2823 ] {} TCPHandler: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311ce6af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311cb345 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:297: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000304db7a4 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304efb26 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304ef90a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000304ec72f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:30:45.096243 [ 34277 ] {e48a5220-945d-4351-b0c1-e88c567132c5} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 83, line 28) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:45.142328 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:45.886024 [ 46285 ] {0594922f-f2d9-4a13-b1fd-6c0b9e1d02e6} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37618) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 13. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 16. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 17. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:30:45.910343 [ 46285 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 13. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 16. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 17. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:30:46.230297 [ 2823 ] {5b3a242b-d6ea-4d95-bd7b-8843829c0340} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.nonexist' in scope SELECT x FROM test_9m795vjx.nonexist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37702) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 2) (in query: create materialized view o refresh every 1 second (x Int64) engine Memory as select x from nonexist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc75f20 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:46.240273 [ 2823 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.nonexist' in scope SELECT x FROM test_9m795vjx.nonexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc75f20 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:46.313322 [ 2823 ] {8b92c814-5f49-4b08-8d27-8433cc3b467a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.nonexist' in scope SELECT x FROM test_9m795vjx.nonexist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37702) (comment: 02932_refreshable_materialized_views_2.sh) (query 2, line 3) (in query: create materialized view o (x Int64) engine Memory as select x from nonexist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc75f20 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:46.330390 [ 2823 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_9m795vjx.nonexist' in scope SELECT x FROM test_9m795vjx.nonexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc75f20 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:46.429774 [ 2823 ] {1c190bd5-3a09-455b-809f-2030a1c1f52c} executeQuery: Code: 81. DB::Exception: Database nope does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37702) (comment: 02932_refreshable_materialized_views_2.sh) (query 3, line 4) (in query: create materialized view o (x Int64) engine Memory as select x from nope.nonexist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa05e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4b65df 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d13fbf3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29c14 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc581e1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc75f20 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:46.495651 [ 2823 ] {} TCPHandler: Code: 81. DB::Exception: Database nope does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5fa05e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4b65df 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d13fbf3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc29c14 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc581e1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x000000002dc75f20 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cee6 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:48.105627 [ 3766 ] {a50ed040-fa28-4846-92f7-19454f8a2974} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37716) (comment: 01499_log_deadlock.sql) (query 12, line 22) (in query: CREATE TABLE t (x UInt8) ENGINE = StripeLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:48.120730 [ 3766 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:48.460381 [ 5379 ] {714a5700-71cf-43ba-bc17-1209c9c1bd43} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42018) (comment: 02932_refreshable_materialized_views_2.sh) (in query: DROP DATABASE IF EXISTS test_9m795vjx SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:48.471697 [ 5379 ] {714a5700-71cf-43ba-bc17-1209c9c1bd43} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:48.642715 [ 34277 ] {041dac6a-1304-43fb-a522-35fb2f756c84} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 101, line 34) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:48.670473 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.237376 [ 2823 ] {83c59c03-3f1b-4bc9-afa1-6978726222f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=856). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37772) (comment: 01824_move_to_prewhere_many_columns.sql) (query 13, line 33) (in query: INSERT INTO t_move_to_prewhere SELECT 1, number % 2 = 0, number % 3 = 0, number % 5 = 0, repeat('a', 1000) FROM numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.264519 [ 2823 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=856). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.520694 [ 34277 ] {16bc4654-04ea-4e67-bf6b-764ec25657aa} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 113, line 38) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.552765 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.638908 [ 5379 ] {ea47659d-f80e-4124-bad5-877e58058eb8} executeQuery: Code: 291. DB::Exception: Cannot log errors in path `/var/lib/clickhouse/user_files/../error_file`, because it is not inside `/var/lib/clickhouse/user_files/`: While executing File. (DATABASE_ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42526) (comment: 02453_check_path_in_errors_logger.sql) (query 2, line 2) (in query: select * from file(02453_data.jsonl, auto, 'x UInt32') settings input_format_allow_errors_num=1, input_format_record_errors_file_path='../error_file';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Processors/Formats/InputFormatErrorsLogger.cpp:50: DB::InputFormatErrorsLogger::InputFormatErrorsLogger(std::shared_ptr const&) @ 0x0000000031858e68 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x00000000317464d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000003174633a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::FormatFactory::getInput(String const&, DB::ReadBuffer&, DB::Block const&, std::shared_ptr const&, unsigned long, std::optional const&, std::optional, std::optional, bool, DB::CompressionMethod, bool) const @ 0x0000000031736b99 9. ./build_docker/./src/Storages/StorageFile.cpp:1443: DB::StorageFileSource::generate() @ 0x00000000303e9c00 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.657073 [ 5379 ] {} TCPHandler: Code: 291. DB::Exception: Cannot log errors in path `/var/lib/clickhouse/user_files/../error_file`, because it is not inside `/var/lib/clickhouse/user_files/`: While executing File. (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Processors/Formats/InputFormatErrorsLogger.cpp:50: DB::InputFormatErrorsLogger::InputFormatErrorsLogger(std::shared_ptr const&) @ 0x0000000031858e68 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x00000000317464d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000003174633a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::FormatFactory::getInput(String const&, DB::ReadBuffer&, DB::Block const&, std::shared_ptr const&, unsigned long, std::optional const&, std::optional, std::optional, bool, DB::CompressionMethod, bool) const @ 0x0000000031736b99 9. ./build_docker/./src/Storages/StorageFile.cpp:1443: DB::StorageFileSource::generate() @ 0x00000000303e9c00 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.798355 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.803241 [ 2823 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.804141 [ 2823 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.806968 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.830458 [ 5072 ] {b684bf96-f80c-40ff-b45a-9588fe4b9338} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37680) (comment: 00850_global_join_dups.sql) (query 15, line 34) (in query: SELECT * FROM remote('127.0.0.2', system.one) GLOBAL INNER JOIN ( SELECT * FROM ( SELECT dummy FROM remote('127.0.0.2', system.one) ) t1_00850 GLOBAL INNER JOIN ( SELECT dummy FROM remote('127.0.0.3', system.one) ) t2_00850 USING dummy ) USING dummy;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:30:50.924205 [ 5072 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 8. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:315: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000030849350 9. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000030843399 10. ./build_docker/./src/Storages/StorageDistributed.cpp:837: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003039c503 11. ./build_docker/./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) @ 0x000000002ddac77e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 13. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.975991 [ 34277 ] {13943ae1-566a-430b-b139-7a7af28e7243} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 116, line 39) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:50.992095 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:51.835125 [ 34277 ] {4042fbd9-89f5-4f81-88dd-3e44e4354e6f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 122, line 41) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:51.841963 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:52.009902 [ 3766 ] {6bca13d2-2411-4062-81a9-004c6d5bce19} executeQuery: Code: 117. DB::Exception: Incorrect state of aggregate function 'nothingNull', it should contain exactly one zero byte, while it is 1: In scope SELECT CAST('\0', 'AggregateFunction(nothingArrayIf, Array(Nullable(Nothing)), Nullable(Nothing))'). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42566) (comment: 02731_nothing_deserialization.sql) (query 1, line 1) (in query: SELECT CAST('\x01\x00' AS AggregateFunction(nothingArrayIf, Array(Nullable(Nothing)), Nullable(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned int&&) @ 0x0000000027ef7dcf 5. ./src/AggregateFunctions/AggregateFunctionNothing.h:101: DB::AggregateFunctionNothingImpl::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027ef9559 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:30:52.024436 [ 3766 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect state of aggregate function 'nothingNull', it should contain exactly one zero byte, while it is 1: In scope SELECT CAST('\0', 'AggregateFunction(nothingArrayIf, Array(Nullable(Nothing)), Nullable(Nothing))'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned int&&) @ 0x0000000027ef7dcf 5. ./src/AggregateFunctions/AggregateFunctionNothing.h:101: DB::AggregateFunctionNothingImpl::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027ef9559 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:30:52.983583 [ 34277 ] {a54aacbd-98da-4c74-875c-910a9d08ea67} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 128, line 43) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.009349 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.044234 [ 10341 ] {75698b5c-67e7-408f-8817-fae34cd68988} executeQuery: Code: 6. DB::Exception: Neither IPv4 nor IPv6 address: 'unparsable': In scope SELECT isIPAddressInRange('unparsable', '127.0.0.0/8'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 34, line 54) (in query: SELECT isIPAddressInRange('unparsable', '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. (anonymous namespace)::IPAddressVariant::IPAddressVariant(std::basic_string_view>) @ 0x000000001cbbf07c 6. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001cbc07cd 7. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbc0103 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:53.053869 [ 10341 ] {} TCPHandler: Code: 6. DB::Exception: Neither IPv4 nor IPv6 address: 'unparsable': In scope SELECT isIPAddressInRange('unparsable', '127.0.0.0/8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. (anonymous namespace)::IPAddressVariant::IPAddressVariant(std::basic_string_view>) @ 0x000000001cbbf07c 6. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001cbc07cd 7. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbc0103 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:53.063434 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.068027 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.152529 [ 10341 ] {b63cc20d-1090-418e-a12c-51c5734087da} executeQuery: Code: 6. DB::Exception: The text does not contain '/': unparsable: In scope SELECT isIPAddressInRange('127.0.0.1', 'unparsable'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 35, line 55) (in query: SELECT isIPAddressInRange('127.0.0.1', 'unparsable');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. (anonymous namespace)::parseIPWithCIDR(std::basic_string_view>) @ 0x000000001cbbf2f8 6. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001cbc0807 7. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbc0103 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:53.177780 [ 10341 ] {} TCPHandler: Code: 6. DB::Exception: The text does not contain '/': unparsable: In scope SELECT isIPAddressInRange('127.0.0.1', 'unparsable'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. (anonymous namespace)::parseIPWithCIDR(std::basic_string_view>) @ 0x000000001cbbf2f8 6. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001cbc0807 7. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbc0103 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:53.266579 [ 3461 ] {14629aee-c55d-4a68-9f0e-c704fd2ba5a6::all_1_1_0_81} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:53.268600 [ 3461 ] {14629aee-c55d-4a68-9f0e-c704fd2ba5a6::all_1_1_0_81} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:53.269666 [ 3461 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {14629aee-c55d-4a68-9f0e-c704fd2ba5a6::all_1_1_0_81}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:53.269725 [ 46286 ] {1c7402df-1b12-492f-8662-36cb67e4a395} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_81.txt' with part 'all_1_1_0_80' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c5d4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42592) (comment: 01900_kill_mutation_parallel_long.sh) (query 80, line 80) (in query: alter table data_01900_2 update s = 'bar_80' where 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000030f0c797 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c636 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.283145 [ 46286 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_81.txt' with part 'all_1_1_0_80' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c5d4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000030f0c797 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f0c636 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311de1e5 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311d9b06 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311e0085 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cd96 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.433011 [ 10341 ] {6fedb83a-5b3c-4d89-9987-c25221c1d5da} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 37, line 59) (in query: SELECT isIPAddressInRange(100, '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.442487 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.525218 [ 3766 ] {032d30bd-e1e5-4737-8975-a097725ce372} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 3, line 4) (in query: -- Error cases SELECT dateTimeToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.528881 [ 3766 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.531751 [ 10341 ] {a0857afe-82c4-4596-8af5-e3d8f587ec49} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 38, line 60) (in query: SELECT isIPAddressInRange(NULL, '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.536686 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.608725 [ 3766 ] {7ee0f33f-15c6-4fc8-8c9f-0e3450557645} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 4, line 6) (in query: SELECT dateTime64ToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.611309 [ 3766 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.650977 [ 10341 ] {13d5dfc8-4261-4a1d-b795-20fbd991398d} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 39, line 61) (in query: SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.658669 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.717200 [ 3766 ] {bbd78ec0-2744-4cd9-b3f9-4e1a95d4641c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 5, line 8) (in query: SELECT dateTimeToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085d64a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:53.730860 [ 10341 ] {6ec14077-2153-4e0b-ba5a-873dd3109949} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange('127.0.0.1', 100). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 40, line 62) (in query: SELECT isIPAddressInRange('127.0.0.1', 100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.731070 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085d64a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:53.744795 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange('127.0.0.1', 100). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.853734 [ 10341 ] {796a5089-029a-4dce-8511-4095481c6f59} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 41, line 63) (in query: SELECT isIPAddressInRange(100, NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.870736 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, NULL). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.875223 [ 3766 ] {7879e5b0-2212-49d9-bdb7-3c49a530af0c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 6, line 9) (in query: SELECT dateTime64ToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085e6ea 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:53.888676 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085e6ea 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:30:53.946695 [ 10341 ] {1ff5e3ff-b167-49f0-ae80-090ad9b1b8d7} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37786) (comment: 01774_ip_address_in_range.sql) (query 42, line 64) (in query: WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.953236 [ 10341 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cbc049d 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.982032 [ 3766 ] {679be1cc-80e9-45f1-b4a5-14d4ec133e9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 7, line 11) (in query: SELECT dateTimeToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:53.987516 [ 3766 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:54.058557 [ 3766 ] {88fc17e1-a76e-49c1-adf5-2b23fbd95e59} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 8, line 12) (in query: SELECT dateTime64ToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:54.070525 [ 3766 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:30:54.160183 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:54.173447 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:30:54.218929 [ 3766 ] {aee27795-39fe-42c7-a546-71b907543fc2} executeQuery: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 9, line 14) (in query: SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085d383 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:54.231296 [ 3766 ] {} TCPHandler: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085d383 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:54.509759 [ 3766 ] {dfc48c84-51fd-490f-b024-b9558ba2aafe} executeQuery: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42610) (comment: 01942_dateTimeToSnowflake.sql) (query 10, line 15) (in query: SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085e401 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:54.518569 [ 3766 ] {} TCPHandler: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085e401 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:30:54.535396 [ 5379 ] {167b26e7-2055-43df-93af-860daaa41f52} executeQuery: Code: 60. DB::Exception: Table test_w8cme6nd.ghdata_2 does not exist. Maybe you meant test_15.data_r2?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42672) (comment: 01825_type_json_ghdata_insert_select.sh) (query 1, line 1) (in query: INSERT INTO ghdata_2 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:54.560664 [ 5379 ] {} TCPHandler: Code: 60. DB::Exception: Table test_w8cme6nd.ghdata_2 does not exist. Maybe you meant test_15.data_r2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:55.631452 [ 34260 ] {df80fcd3-4115-4183-99c3-c383af7c4a85} executeQuery: Code: 60. DB::Exception: Table test_w8cme6nd.ghdata_2_from_string does not exist. Maybe you meant test_w8cme6nd.ghdata_2_string?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42762) (comment: 01825_type_json_ghdata_insert_select.sh) (query 1, line 1) (in query: INSERT INTO ghdata_2_from_string SELECT data FROM ghdata_2_string), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:55.641967 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_w8cme6nd.ghdata_2_from_string does not exist. Maybe you meant test_w8cme6nd.ghdata_2_string?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:56.208368 [ 34260 ] {d90ad3bb-5ab4-4802-b796-5524f3c8f543} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata_2_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string). (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42796) (comment: 01825_type_json_ghdata_insert_select.sh) (query 1, line 1) (in query: SELECT (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string) = (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:56.223513 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata_2_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:30:56.686211 [ 3455 ] {f26fb87d-7fd7-4b74-9725-c5b3ed26b429::202507_1_126_25} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:56.687581 [ 3455 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f26fb87d-7fd7-4b74-9725-c5b3ed26b429::202507_1_126_25}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=20, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:57.006839 [ 34277 ] {cc2133f5-08b0-4b8e-9cb6-2f504e90431b} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 146, line 49) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:57.013681 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:57.022479 [ 34260 ] {54133caf-c332-4855-baec-a158f3557d91} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42820) (query 1, line 1) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:30:57.032333 [ 34260 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:57.302874 [ 34260 ] {8db7355d-e368-47c7-82bb-b4a7b587f1b7} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42836) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:57.345252 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.161786 [ 34273 ] {bdfadc93-d645-4028-af72-b4b604d7bd46} executeQuery: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42862) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 1, line 1) (in query: SELECT lambda(tuple(1), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.161841 [ 2824 ] {600fd728-c9e9-4160-92f9-fedff64ac7bd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42878) (query 1, line 1) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.165284 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.172144 [ 2824 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.267723 [ 34273 ] {021a780c-90b6-4e9b-994b-933930eef731} executeQuery: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42862) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 2, line 2) (in query: SELECT lambda(tuple(1, 2), materialize(1) + x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.277222 [ 34273 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba9b27 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.523475 [ 3816 ] {91b5c93b-53bf-4cee-b00f-2b83c0ef7e86} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42888) (comment: 03101_analyzer_identifiers_1.sql) (query 2, line 5) (in query: DROP DATABASE IF EXISTS test_5), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb6fe2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.538197 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb6fe2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.681954 [ 34277 ] {624d14aa-5671-49f4-b529-664dc719cd3d} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 155, line 52) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:58.686347 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:30:59.231657 [ 34260 ] {fa5b6afc-dbfe-4dd9-bd5d-5a6ffd77135d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55732) (comment: 01499_log_deadlock.sql) (query 2, line 4) (in query: CREATE TABLE t (x UInt8) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:59.252105 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:59.992576 [ 3816 ] {4a7eb06f-ba5a-49f9-bd65-6c0088151d0f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55754) (comment: 00084_summing_merge_tree.sql) (query 3, line 4) (in query: CREATE TABLE summing_merge_tree (d Date, a String, x UInt32, y UInt64, z Float64) ENGINE = SummingMergeTree(d, a, 8192);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:30:59.996051 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:00.950595 [ 34273 ] {142a8a97-62f4-407d-9b80-2c85109e1539} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55794) (comment: 02536_delta_gorilla_corruption.sql) (query 5, line 11) (in query: CREATE TABLE bug_delta_gorilla (`value_bug` UInt64 CODEC(Delta, Gorilla)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 226466802, 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 = 256095052, compact_parts_max_bytes_to_buffer = 421166312, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 17770826, merge_max_block_size = 21389, 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 = 1, min_merge_bytes_to_use_direct_io = 1, 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 = false, marks_compress_block_size = 12203, primary_key_compress_block_size = 16116, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false AS SELECT 0 FROM numbers(20000000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:00.968248 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:01.734958 [ 34273 ] {e01cc1ca-5bb2-4378-b253-6364b104bf3b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55826) (comment: 00584_view_union_all.sql) (query 3, line 4) (in query: CREATE TABLE Test_00584 ( createdDate Date, str String, key Enum8('A' = 0, 'B' = 1, 'ALL' = 2), a Int64 ) ENGINE = MergeTree(createdDate, str, 8192);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:01.745658 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:02.345561 [ 3815 ] {49c38ffa-00e8-4817-928c-59f2c223278d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55852) (comment: 01716_drop_rename_sign_column.sql) (query 2, line 3) (in query: CREATE TABLE signed_table (`k` UInt32, `v` String, `s` Int8) ENGINE = CollapsingMergeTree(s) ORDER BY k SETTINGS index_granularity = 422, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 60, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 82274072, compact_parts_max_granules_to_buffer = 148, compact_parts_merge_max_bytes_to_prefetch_part = 23067444, merge_max_block_size = 9294, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 215797, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6155780563, index_granularity_bytes = 30834888, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 12792, primary_key_compress_block_size = 69681, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:02.359189 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:03.221143 [ 6875 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003117f00d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003117ef02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x0000000032823380 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x00000000328210b2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x000000003281ffaf 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003282d1fe 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:03.232963 [ 3063 ] {} test_3.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.241206 [ 3089 ] {} test_1.t1_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.242177 [ 3134 ] {} test_3.deduplication (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.245779 [ 3119 ] {} test_1.t1_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.246963 [ 3038 ] {} test_13.dep2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.248414 [ 3073 ] {} test_1.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.249261 [ 3121 ] {} test_11.t_json_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.250143 [ 3108 ] {} test_1.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.250811 [ 3043 ] {} test_11.table_rename_with_ttl (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.252293 [ 2951 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.253870 [ 3067 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:31:03.256254 [ 2991 ] {} test_15.data_r2 (9f5cb420-3210-41c8-ae0f-a46444c4b569): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/test_15/replicas/r2), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003063ff0f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:03.275535 [ 2940 ] {} test_15.data_r2 (9f5cb420-3210-41c8-ae0f-a46444c4b569): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:03.476458 [ 34260 ] {be039424-7479-4673-8cf0-0100404a9866} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_2/log/query-0000000003/active. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34020) (comment: 00041_big_array_join.sql) (in query: DROP DATABASE IF EXISTS test_j87ppvms SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af99c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af994d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275eecf 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275e8cc 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:899: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x0000000032767fd6 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:918: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x00000000327684fc 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:918: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x00000000327684fc 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:918: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x00000000327684fc 12. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:986: zkutil::ZooKeeper::tryRemoveRecursive(String const&, unsigned int)::$_0::operator()() const @ 0x000000003276a201 13. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:991: zkutil::ZooKeeper::tryRemoveRecursive(String const&, unsigned int) @ 0x0000000032769ef4 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1675: DB::DatabaseReplicated::drop(std::shared_ptr) @ 0x000000002c79b127 15. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8816 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:03.485917 [ 34260 ] {be039424-7479-4673-8cf0-0100404a9866} DynamicQueryHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_2/log/query-0000000003/active. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af99c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af994d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275eecf 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275e8cc 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:899: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x0000000032767fd6 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:918: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x00000000327684fc 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:918: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x00000000327684fc 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:918: zkutil::ZooKeeper::tryRemoveChildrenRecursive(String const&, bool, zkutil::RemoveException) @ 0x00000000327684fc 12. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:986: zkutil::ZooKeeper::tryRemoveRecursive(String const&, unsigned int)::$_0::operator()() const @ 0x000000003276a201 13. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:991: zkutil::ZooKeeper::tryRemoveRecursive(String const&, unsigned int) @ 0x0000000032769ef4 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1675: DB::DatabaseReplicated::drop(std::shared_ptr) @ 0x000000002c79b127 15. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8816 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:04.077207 [ 2823 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:04.720920 [ 34277 ] {f782c9b4-54ba-4633-99f8-1f5d2d3ff4d8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 182, line 61) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:31:04.733484 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:31:04.829173 [ 34277 ] {2982952e-2784-4a65-ade5-e6a193fd3a16} executeQuery: Code: 60. DB::Exception: Table test_13.mt_00763_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 183, line 61) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:04.836054 [ 34277 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.mt_00763_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:04.948817 [ 3815 ] {5425d6da-1baa-46a4-95e1-6bbc446226f8} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34036) (comment: 00732_quorum_insert_have_data_before_quorum_zookeeper_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_a9k7fn2v ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:04.954038 [ 3815 ] {5425d6da-1baa-46a4-95e1-6bbc446226f8} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:05.425110 [ 3815 ] {403829d1-f80c-40a0-9bb9-ef9d53a495ef} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34096) (comment: 02915_analyzer_fuzz_2.sql) (in query: CREATE DATABASE IF NOT EXISTS test_flc8znqr ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:05.426998 [ 3815 ] {403829d1-f80c-40a0-9bb9-ef9d53a495ef} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:05.459049 [ 46285 ] {43f7f2f0-172b-4330-b127-83c0c0542bd4} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_9.mv_from_base_to_target, it is a Materialized View without storage. Use "AS test_9.target_table" instead. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55888) (comment: 03161_create_table_as_mv.sql) (query 12, line 14) (in query: CREATE TABLE other_table_2 AS mv_from_base_to_target;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1344: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc7412e 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc694ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:05.479700 [ 46285 ] {} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_9.mv_from_base_to_target, it is a Materialized View without storage. Use "AS test_9.target_table" instead. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1344: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc7412e 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc694ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:05.812838 [ 10341 ] {c1f484ee-8039-4347-a1e4-596b1a50e3ff} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34128) (comment: 02301_harmful_reexec.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5pg7c564 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:05.815150 [ 10341 ] {c1f484ee-8039-4347-a1e4-596b1a50e3ff} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:06.446844 [ 46285 ] {2bf40273-bd11-4729-a53f-4fc38767b10a} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34142) (comment: 01276_alter_rename_column_materialized_expr.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mhtll780 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:06.449314 [ 46285 ] {2bf40273-bd11-4729-a53f-4fc38767b10a} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:06.736293 [ 46285 ] {16a121b7-d789-4b4d-aec9-784daacff3a9} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34152) (comment: 02184_storage_add_support_ttl.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l0n5cyzl ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:06.738541 [ 46285 ] {16a121b7-d789-4b4d-aec9-784daacff3a9} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:07.203645 [ 46294 ] {19b78e92-0b12-4fa7-ad4b-a34d12144b4a} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34162) (comment: 00383_utf8_validation.sql) (in query: CREATE DATABASE IF NOT EXISTS test_luxhjbn4 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:07.205903 [ 46294 ] {19b78e92-0b12-4fa7-ad4b-a34d12144b4a} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:07.766985 [ 10341 ] {29191f0b-6e47-449b-9886-4ade631de6cd} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34168) (comment: 01872_initial_query_start_time.sh) (in query: CREATE DATABASE IF NOT EXISTS test_q5zr37ig ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:07.772754 [ 10341 ] {29191f0b-6e47-449b-9886-4ade631de6cd} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:08.134561 [ 10341 ] {d3e04be3-91b2-43a5-ad4b-392829e14745} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34180) (comment: 03258_dynamic_in_functions_weak_ptr_exception.sql) (in query: CREATE DATABASE IF NOT EXISTS test_onlg19qc ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:08.136524 [ 10341 ] {d3e04be3-91b2-43a5-ad4b-392829e14745} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:08.415082 [ 10341 ] {621b4bac-9411-4d39-9cb2-fc74d9fe31bb} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34190) (comment: 01269_create_with_null.sql) (in query: CREATE DATABASE IF NOT EXISTS test_y3n76i4r ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:08.417360 [ 10341 ] {621b4bac-9411-4d39-9cb2-fc74d9fe31bb} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:08.661323 [ 34277 ] {09924e20-3f73-4b25-9712-89bc71b05680} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 203, line 68) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:08.674320 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:08.873663 [ 3816 ] {f37570a9-28eb-4431-ab56-5422d6b7b2ef} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34196) (comment: 02013_zlib_read_after_eof.sh) (in query: CREATE DATABASE IF NOT EXISTS test_0uif26ko ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:08.881996 [ 3816 ] {f37570a9-28eb-4431-ab56-5422d6b7b2ef} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:09.234280 [ 10341 ] {81cc2e31-2afe-44d9-b7c5-5d8b9d8785f0} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43828) (comment: 03217_primary_index_memory_leak.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ra2m2or5 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:09.236164 [ 10341 ] {81cc2e31-2afe-44d9-b7c5-5d8b9d8785f0} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:09.649268 [ 46282 ] {4b16be46-fe49-4b57-aeef-4a50d92c4dee} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43838) (comment: 01039_row_policy_dcl.sh) (in query: CREATE DATABASE IF NOT EXISTS test_zg21ge6m ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:09.651161 [ 46282 ] {4b16be46-fe49-4b57-aeef-4a50d92c4dee} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:09.995232 [ 46282 ] {b407f7bd-cdf5-4e44-92c1-5ad55e80c190} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43862) (comment: 01232_json_as_string_format.sh) (in query: CREATE DATABASE IF NOT EXISTS test_lj170dth ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:09.999157 [ 46282 ] {b407f7bd-cdf5-4e44-92c1-5ad55e80c190} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:10.340233 [ 46286 ] {632474f4-b6b1-4976-b893-d870424f23ff} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43878) (comment: 02995_preliminary_filters_duplicated_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9zmep1ff ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:10.342164 [ 46286 ] {632474f4-b6b1-4976-b893-d870424f23ff} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:10.528954 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:10.742349 [ 3766 ] {34d84f58-1d3e-43a1-9eb1-205066fe6dba} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43902) (comment: 01428_hash_set_nan_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rxljzuad ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:10.745585 [ 3766 ] {34d84f58-1d3e-43a1-9eb1-205066fe6dba} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:11.092232 [ 3766 ] {fb0508aa-1051-4fbe-b27e-a001f418edea} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43916) (comment: 01035_concurrent_move_partition_from_table_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_guzwf4s0 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:11.093969 [ 3766 ] {fb0508aa-1051-4fbe-b27e-a001f418edea} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:11.397546 [ 46294 ] {32cc18a7-3b97-4be3-823e-6311e76678ec} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43928) (comment: 02096_rename_atomic_hang.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2bit7vhs ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:11.402571 [ 46294 ] {32cc18a7-3b97-4be3-823e-6311e76678ec} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:11.707816 [ 46286 ] {2b2cebc2-5305-4405-914c-95664758ca55} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43946) (comment: 01076_parallel_alter_replicated_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_lgesmsfe ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:11.710543 [ 46286 ] {2b2cebc2-5305-4405-914c-95664758ca55} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:12.039563 [ 46294 ] {fdd1ea5d-b94b-48de-8811-119ddf9ed520} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43952) (comment: 02710_show_table.sql) (in query: CREATE DATABASE IF NOT EXISTS test_onmuqdfy ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:12.050852 [ 46294 ] {fdd1ea5d-b94b-48de-8811-119ddf9ed520} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:12.445814 [ 46286 ] {a85602d2-dfa5-4b3d-9f02-7b7ed513022b} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43964) (comment: 01646_system_restart_replicas_smoke.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ym8grnne ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:12.449415 [ 46286 ] {a85602d2-dfa5-4b3d-9f02-7b7ed513022b} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:12.613796 [ 34277 ] {974d550c-5b2a-4528-a6b5-735de5cc3688} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 224, line 75) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:12.626532 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:13.010365 [ 10341 ] {269bd317-e007-43f4-8e6f-b99406e8141c} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43968) (comment: 00933_test_fix_extra_seek_on_compressed_cache.sh) (in query: CREATE DATABASE IF NOT EXISTS test_1tkc503c ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:13.013264 [ 10341 ] {269bd317-e007-43f4-8e6f-b99406e8141c} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:13.425170 [ 46286 ] {4ad0220c-5e55-4980-8ee7-25153c8d118f} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43988) (comment: 02115_rewrite_local_join_right_distribute_table.sql) (in query: CREATE DATABASE IF NOT EXISTS test_kzq34uft ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:13.426582 [ 46286 ] {4ad0220c-5e55-4980-8ee7-25153c8d118f} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:13.652627 [ 46282 ] {cc419b19-7ae7-4ca7-8dac-1b2365ee9f66} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44008) (comment: 01356_view_threads.sql) (in query: CREATE DATABASE IF NOT EXISTS test_kzw3vfrv ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:13.655970 [ 46282 ] {cc419b19-7ae7-4ca7-8dac-1b2365ee9f66} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:13.874136 [ 46282 ] {063d0885-42f7-4e63-affb-a956fe7567f7} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44016) (comment: 01721_engine_file_truncate_on_insert.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7fvibype ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:13.875680 [ 46282 ] {063d0885-42f7-4e63-affb-a956fe7567f7} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:14.091228 [ 34277 ] {5053753f-258c-49d0-9922-c9e65d3721a4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 233, line 78) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.120639 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.176352 [ 46282 ] {78aae2ee-783c-4e33-9c9b-65076b21e7f4} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44032) (comment: 03320_insert_close_connection_on_error.sh) (in query: CREATE DATABASE IF NOT EXISTS test_loho3qa5 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.182877 [ 46282 ] {78aae2ee-783c-4e33-9c9b-65076b21e7f4} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:14.517286 [ 32979 ] {5a130ad0-d71e-4db8-91bc-490a636d2ffd} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44060) (comment: 01275_parallel_mv.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xj24mv3i ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.518769 [ 32979 ] {5a130ad0-d71e-4db8-91bc-490a636d2ffd} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:14.604789 [ 29256 ] {c14c0e46-3b05-411d-aee6-021b4da5690e} executeQuery: Code: 36. DB::Exception: Argument __table1.a of GROUPING function is not a part of GROUP BY clause [__table1.b, __table1.a]. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32816) (comment: 02315_grouping_constant_folding.sql) (query 4, line 7) (in query: -- { echoOn } SELECT count() AS amount, a, b, GROUPING(a, b) FROM test02315 GROUP BY GROUPING SETS ((a, b), (a), ()) ORDER BY (amount, a, b) SETTINGS force_grouping_standard_compatibility=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>::type>, String&&, fmt::v11::join_view, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>&&) @ 0x000000002ccbac35 5. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:98: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb9f08 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb9ad5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb9ad5 8. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:261: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb71b1 9. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:289: DB::GroupingFunctionsResolvePass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002ccb524d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.623648 [ 29256 ] {} TCPHandler: Code: 36. DB::Exception: Argument __table1.a of GROUPING function is not a part of GROUP BY clause [__table1.b, __table1.a]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>::type>, String&&, fmt::v11::join_view, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>&&) @ 0x000000002ccbac35 5. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:98: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb9f08 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb9ad5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb9ad5 8. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:261: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccb71b1 9. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:289: DB::GroupingFunctionsResolvePass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002ccb524d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.815698 [ 46282 ] {89b2e415-9e13-46de-9227-943ffc556696} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44078) (comment: 00154_avro.sql) (in query: CREATE DATABASE IF NOT EXISTS test_uqsslrog ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:14.817131 [ 46282 ] {89b2e415-9e13-46de-9227-943ffc556696} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:15.092441 [ 5379 ] {59285311-57a5-4c52-8bbb-203dda59cadf} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 20.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32804) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 10, line 20) (in query: SELECT a FROM t_max_rows_to_read ORDER BY a LIMIT 20 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.109175 [ 5379 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 20.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.219780 [ 5379 ] {91b5e3ca-697a-4ab6-b36c-428f6eb4efe6} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32804) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 11, line 21) (in query: SELECT a FROM t_max_rows_to_read WHERE a > 10 ORDER BY a LIMIT 5 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.222283 [ 5379 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.243310 [ 3766 ] {8168ce67-5fd2-4fe0-8591-78f2ddf124e5} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44082) (comment: 00021_3_select_with_in.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pa7lyi6c ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.244861 [ 3766 ] {8168ce67-5fd2-4fe0-8591-78f2ddf124e5} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:15.268575 [ 5379 ] {afdc432b-28fd-4211-a812-99b03fbcda92} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32804) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 12, line 22) (in query: SELECT a FROM t_max_rows_to_read WHERE a = 10 OR a = 20 FORMAT Null SETTINGS max_rows_to_read = 4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.281543 [ 5379 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.440251 [ 34277 ] {f528a05e-6fce-4ff1-9c3e-058f4e19d376} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 242, line 81) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.461268 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.834671 [ 10341 ] {49340535-74aa-4e19-93f6-90089e904217} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44098) (comment: 03321_clickhouse_local_initialization_not_too_slow_even_under_sanitizers.sh) (in query: CREATE DATABASE IF NOT EXISTS test_7z6jq8q7 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.838372 [ 10341 ] {49340535-74aa-4e19-93f6-90089e904217} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:15.866936 [ 3766 ] {47cb2aba-a89e-40eb-8090-3174902ddd22} executeQuery: Code: 57. DB::Exception: Table test_xihxb8mh.t_json_empty_parts already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02421_new_type_json_empty_parts.sh) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_xihxb8mh.t_json_empty_parts UUID 'dc2a953c-c6fd-4718-815d-6e8ba6810dd6' (`id` UInt64, `d` Date, `data` JSON) ENGINE = MergeTree ORDER BY id TTL d WHERE (id % 2) = 1 SETTINGS old_parts_lifetime = 5, index_granularity = 54957, min_bytes_for_wide_part = 519685672, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 68, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 26240909, compact_parts_max_granules_to_buffer = 223, compact_parts_merge_max_bytes_to_prefetch_part = 26531638, merge_max_block_size = 3194, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 882332, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8159306173, index_granularity_bytes = 15026318, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 65, 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 = 62202, primary_key_compress_block_size = 21848, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.893634 [ 3766 ] {47cb2aba-a89e-40eb-8090-3174902ddd22} executeQuery: Code: 57. DB::Exception: Table test_xihxb8mh.t_json_empty_parts already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32858) (comment: 02421_new_type_json_empty_parts.sh) (query 1, line 1) (in query: CREATE TABLE t_json_empty_parts (`id` UInt64, `d` Date, `data` JSON) ENGINE = MergeTree ORDER BY id TTL d WHERE (id % 2) = 1 SETTINGS old_parts_lifetime = 5, index_granularity = 54957, min_bytes_for_wide_part = 519685672, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 68, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 26240909, compact_parts_max_granules_to_buffer = 223, compact_parts_merge_max_bytes_to_prefetch_part = 26531638, merge_max_block_size = 3194, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 882332, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8159306173, index_granularity_bytes = 15026318, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 65, 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 = 62202, primary_key_compress_block_size = 21848, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:31:15.906460 [ 3766 ] {} TCPHandler: Code: 57. DB::Exception: Table test_xihxb8mh.t_json_empty_parts already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:31:16.109810 [ 10341 ] {077d1694-3b8c-4a66-af34-5cdff05ebaab} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44122) (comment: 02416_rename_database_rbac.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ynptwpbp ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:16.111280 [ 10341 ] {077d1694-3b8c-4a66-af34-5cdff05ebaab} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:16.664894 [ 5826 ] {853ef61c-c25f-48c5-a426-034219c284b7} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44150) (comment: 02726_async_insert_flush_stress.sh) (in query: CREATE DATABASE IF NOT EXISTS test_3co8x4ol ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:16.669566 [ 5826 ] {853ef61c-c25f-48c5-a426-034219c284b7} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:17.183622 [ 46294 ] {8975cda8-810b-4432-8e76-7723d5c22ad8} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44176) (comment: 00176_distinct_limit_by_limit_bug_43377.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rdblex9s ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:17.185292 [ 46294 ] {8975cda8-810b-4432-8e76-7723d5c22ad8} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:17.608893 [ 5826 ] {8f985978-13b3-4a4c-a280-2ec29142eb85} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44188) (comment: 00069_duplicate_aggregation_keys.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nz8b5qko ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:17.610557 [ 5826 ] {8f985978-13b3-4a4c-a280-2ec29142eb85} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:17.999698 [ 6126 ] {4d81909b-bff4-40d5-9867-9f0196bf12ad} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44208) (comment: 02098_sql_user_defined_functions_aliases.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9rwvqoal ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:18.100930 [ 6126 ] {4d81909b-bff4-40d5-9867-9f0196bf12ad} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:18.604527 [ 5826 ] {bd0724cd-37fb-4798-8f1d-d0a9716a604b} executeQuery: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44220) (comment: 01155_rename_move_materialized_view.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rr5ali8a ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:18.605928 [ 5826 ] {bd0724cd-37fb-4798-8f1d-d0a9716a604b} DynamicQueryHandler: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /test/db/test_2/replicas/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x000000003278255c 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1595: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x0000000032771cd0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x00000000327654bd 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:725: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002c76ecf8 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:531: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b83a 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 10. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:21.253151 [ 3815 ] {a7109b96-a42d-41a5-8b1f-562e4906efeb} 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.3.20372.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_8bzbgp3s_data4.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53016) (comment: 02267_file_globs_schema_inference.sh) (query 1, line 1) (in query: select * from file('02267_file_globs_schema_inference_test_8bzbgp3s_data*.jsonl') settings schema_inference_use_cache_for_file=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303df7fa 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303e0f46 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303e1797 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cae74 15. ./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 @ 0x00000000284c8039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cd40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:31:21.273633 [ 3815 ] {} 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.3.20372.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_8bzbgp3s_data4.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076d88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c991c 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303dd28d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303ddc44 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303df7fa 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303e0f46 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303e1797 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cb043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284cae74 15. ./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 @ 0x00000000284c8039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cd40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:31:21.497218 [ 34277 ] {4e8cb9c2-bd83-475f-952a-3d2e5546ba22} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 278, line 93) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:21.509770 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:21.969173 [ 34277 ] {2f016edf-4e7a-4eb8-9697-ae8dc66941b6} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 281, line 94) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:21.991307 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:23.829883 [ 34277 ] {3eb9d85c-5901-4963-bc20-b89abd6b0199} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 293, line 98) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:23.864658 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:24.180757 [ 5382 ] {6303a272-7ed8-45c9-bfee-1e00be3a9bfe} executeQuery: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53072) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000278c27aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:31:24.196668 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000278c27aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:31:24.273383 [ 34277 ] {792e4606-2e04-4cc5-9c6c-feea9f494658} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 296, line 99) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:24.282701 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:26.660134 [ 46294 ] {9a14ef52-56cf-499c-9a55-b7bdae3bbbee} executeQuery: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53092) (comment: 02985_minmax_index_aggregate_function.sql) (query 2, line 3) (in query: CREATE TABLE t_index_agg_func (`id` UInt64, `v` AggregateFunction(avg, UInt64), INDEX idx_v v TYPE minmax GRANULARITY 1) ENGINE = AggregatingMergeTree ORDER BY id SETTINGS index_granularity = 4, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 72, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 23102330, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 9569371, merge_max_block_size = 1951, 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 = 10737418240, index_granularity_bytes = 12490689, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 63, 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 = 47219, primary_key_compress_block_size = 67512, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000030e8a87e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:31:26.674330 [ 46294 ] {} TCPHandler: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000030e8a87e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7c94d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: 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) @ 0x0000000030c7a954 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:31:27.205572 [ 46294 ] {cc5f159b-0b1b-4d91-94e3-713a7288fd63} executeQuery: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53092) (comment: 02985_minmax_index_aggregate_function.sql) (query 4, line 20) (in query: ALTER TABLE t_index_agg_func ADD INDEX idx_v v TYPE minmax GRANULARITY 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000030e8a87e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:27.239206 [ 46294 ] {} TCPHandler: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexMinMax.cpp:230: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000030e8a87e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c858c7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:28.608110 [ 34277 ] {029345a4-91b8-40fb-ad0c-68421789aa1f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 317, line 106) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:28.613448 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:29.609309 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:29.610462 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:31:29.663247 [ 46286 ] {f9b5da4d-80bc-4df5-bc75-ff961f73b9da} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53160) (comment: 02521_to_custom_day_of_week.sql) (query 8, line 10) (in query: select toDayOfWeek(today(), -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x0000000020abdfbe 6. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020abaf0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:31:29.676667 [ 46286 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x0000000020abdfbe 6. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020abaf0b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:31:29.740906 [ 5379 ] {5ed3ee6f-50d9-48b1-9242-b2623250ed81} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45924) (comment: 03093_virtual_column_override_group_by.sql) (in query: DROP DATABASE IF EXISTS test_9ovmde08 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:29.747861 [ 5379 ] {5ed3ee6f-50d9-48b1-9242-b2623250ed81} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:30.077520 [ 3766 ] {323f95d6-69e2-4176-9589-83d4fce94ab6} executeQuery: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp2(nan). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38996) (comment: 00536_int_exp_overflow.sql) (query 4, line 4) (in query: SELECT intExp2(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::IntExp2Impl::apply(double) @ 0x000000001cbb4994 6. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001cbb45a9 7. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001cbaebba 8. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_111IntExp2ImplENS12_11NameIntExp2ELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001cbad1dc 9. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cba9d53 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:31:30.135413 [ 3766 ] {} TCPHandler: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp2(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::IntExp2Impl::apply(double) @ 0x000000001cbb4994 6. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001cbb45a9 7. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001cbaebba 8. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_111IntExp2ImplENS12_11NameIntExp2ELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001cbad1dc 9. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cba9d53 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:31:30.679534 [ 3766 ] {ebd3ec85-fac4-4e3f-9f59-29ef1f62766c} executeQuery: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp10(nan). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38996) (comment: 00536_int_exp_overflow.sql) (query 8, line 9) (in query: SELECT intExp10(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::IntExp10Impl::apply(double) @ 0x000000001cba85d7 6. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001cba81a9 7. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001cba0b7a 8. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112IntExp10ImplENS12_12NameIntExp10ELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001cb9f19c 9. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb9c393 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:31:30.690487 [ 3766 ] {} TCPHandler: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp10(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::IntExp10Impl::apply(double) @ 0x000000001cba85d7 6. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001cba81a9 7. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001cba0b7a 8. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112IntExp10ImplENS12_12NameIntExp10ELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001cb9f19c 9. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cb9c393 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:31:33.067738 [ 46285 ] {d96adaef-be51-4b1b-a3bc-c6d5712aab52} 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.3.20372.altinityantalya (altinity build)) (from [::1]:39210) (comment: 00910_zookeeper_custom_compression_codecs_replicated_long.sql) (query 5, line 9) (in query: CREATE TABLE compression_codec_replicated1( id UInt64 CODEC(LZ4), data String CODEC(ZSTD), ddd Date CODEC(NONE), somenum Float64 CODEC(ZSTD(2)), somestr FixedString(3) CODEC(LZ4HC(7)), othernum Int64 CODEC(Delta) ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00910/compression_codec_replicated', '1') ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.076732 [ 46285 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.432021 [ 3766 ] {7cd1384b-1003-4cf2-96c3-2731c192539e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39052) (comment: 02501_limits_on_result_for_view.sql) (query 8, line 18) (in query: -- test SELECT * from 02501_view settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.446382 [ 6126 ] {527a7d58-5643-4188-a492-7cf1af0023a5} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 5 and result: 4). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39288) (comment: 00504_insert_miss_columns.sh) (query 1, line 1) (in query: INSERT INTO advertiser_test SELECT *, sipHash64( CAST(adblock AS String) ), CAST(1 AS Int8) FROM advertiser;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.464263 [ 6126 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 5 and result: 4). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.471153 [ 3766 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031de166e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.502561 [ 6022 ] {a449ea40-4bcb-444b-915f-5a1ead90e758} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:51486). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:51486) (comment: 02501_limits_on_result_for_view.sql) (query 8, line 18) (in query: SELECT `__table1`.`a` AS `a` FROM `test_208osm4q`.`02501_test` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x00000000316ad6e3 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:31:33.505982 [ 6022 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:51486). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x00000000316ad6e3 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:31:34.175420 [ 34277 ] {7138a770-7b99-4a2a-b412-b33647f15d41} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 344, line 115) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:34.206183 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:34.443582 [ 6126 ] {22c414cd-e244-4531-a2e9-bec9f19b8440} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:39388). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39388) (comment: 02532_send_logs_level_test.sh) (query 1, line 1) (in query: select * from data SETTINGS merge_tree_read_split_ranges_into_intersecting_and_non_intersecting_injection_probability = 0.0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:727: DB::TCPHandler::runImpl() @ 0x00000000316ad699 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:34.454098 [ 6126 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:39388). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:727: DB::TCPHandler::runImpl() @ 0x00000000316ad699 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:35.228152 [ 3766 ] {36fdf3dc-a9f6-4955-b58b-b16f4dc9c47d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02501_limits_on_result_for_view.sql) (in query: /* ddl_entry=query-0000000007 */ TRUNCATE VIEW IF EXISTS test_208osm4q.`02501_view`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:31:35.258385 [ 3766 ] {36fdf3dc-a9f6-4955-b58b-b16f4dc9c47d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39052) (comment: 02501_limits_on_result_for_view.sql) (query 12, line 25) (in query: DROP VIEW IF EXISTS 02501_view;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:31:35.267498 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:31:36.594043 [ 3815 ] {25dc7c7a-2a3f-439e-b4fe-ed1ff8ef7f42} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39628) (comment: 01825_type_json_in_other_types.sh) (query 1, line 1) (in query: SET allow_experimental_object_type = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:36.605395 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:36.632168 [ 46286 ] {e1878709-930a-40d0-b4d7-db9d579a40a1} executeQuery: Code: 48. DB::Exception: Cannot support collation, please set compatibility_ignore_collation_in_create_table=true. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39614) (comment: 02269_create_table_with_collation.sql) (query 3, line 8) (in query: CREATE TABLE t_02267_collation (x varchar(255) COLLATE utf8_unicode_ci NOT NULL) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:620: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc68626 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:36.636810 [ 46286 ] {} TCPHandler: Code: 48. DB::Exception: Cannot support collation, please set compatibility_ignore_collation_in_create_table=true. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:620: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc68626 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:37.292610 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:37.295983 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:31:37.740658 [ 5105 ] {d1752af0-8d08-4871-ab81-3fbcc9664f1f} executeQuery: Code: 60. DB::Exception: Table test_5.t_json_nested does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39774) (comment: 01825_type_json_in_other_types.sh) (query 1, line 1) (in query: INSERT INTO t_json_nested FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:37.746051 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.t_json_nested does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.088832 [ 46286 ] {78c4e83f-3f4d-40f7-884c-ddb8f5a66ee9} executeQuery: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39794) (comment: 01277_random_fixed_string.sql) (query 1, line 1) (in query: SELECT randomFixedString('string');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020614c79 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.100649 [ 46286 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020614c79 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.184689 [ 5826 ] {c309eda7-d3ef-4a7d-8df7-251bb5e17241} executeQuery: Code: 60. DB::Exception: Table test_5.t_json_nested does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39830) (comment: 01825_type_json_in_other_types.sh) (query 1, line 1) (in query: INSERT INTO t_json_nested FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.215061 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.t_json_nested does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.287581 [ 46286 ] {bc95a877-3d85-4bfe-a163-36dc7dc174e3} executeQuery: Code: 69. DB::Exception: FixedString size must be positive: In scope SELECT randomFixedString(0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39794) (comment: 01277_random_fixed_string.sql) (query 2, line 2) (in query: SELECT randomFixedString(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/DataTypes/DataTypeFixedString.cpp:26: DB::DataTypeFixedString::DataTypeFixedString(unsigned long) @ 0x000000002c432117 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned long const&) @ 0x0000000017e36d1c 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned long const&, 0>(std::allocator const&, unsigned long const&) @ 0x0000000017e36b20 8. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020614aac 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:31:38.305037 [ 46286 ] {} TCPHandler: Code: 69. DB::Exception: FixedString size must be positive: In scope SELECT randomFixedString(0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/DataTypes/DataTypeFixedString.cpp:26: DB::DataTypeFixedString::DataTypeFixedString(unsigned long) @ 0x000000002c432117 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned long const&) @ 0x0000000017e36d1c 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned long const&, 0>(std::allocator const&, unsigned long const&) @ 0x0000000017e36b20 8. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020614aac 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:31:38.532341 [ 46286 ] {5f16da9a-dada-4d6f-b392-60808a45086c} executeQuery: Code: 44. DB::Exception: First argument for function randomFixedString must be constant: In scope SELECT randomFixedString(rand() % 10). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39794) (comment: 01277_random_fixed_string.sql) (query 3, line 3) (in query: SELECT randomFixedString(rand() % 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020614b85 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.555112 [ 46286 ] {} TCPHandler: Code: 44. DB::Exception: First argument for function randomFixedString must be constant: In scope SELECT randomFixedString(rand() % 10). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020614b85 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.573295 [ 5105 ] {2c3db86f-5afc-4e1b-b217-4cf4af297577} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT toTypeName(data) FROM t_json_nested LIMIT 1. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39896) (comment: 01825_type_json_in_other_types.sh) (query 1, line 1) (in query: SELECT toTypeName(data) FROM t_json_nested LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.579503 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT toTypeName(data) FROM t_json_nested LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.946255 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:38.949705 [ 10341 ] {8d688335-13ee-46b4-a4d8-7de08857e696} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT * FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51716) (comment: 01825_type_json_in_other_types.sh) (query 1, line 1) (in query: SELECT * FROM t_json_nested ORDER BY id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:38.988725 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT * FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:39.346712 [ 29256 ] {43451388-ca7b-4727-adcf-675d4e8cf965} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT (data.2)['aa'] AS aa, (data.2)['bb'] AS bb FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51768) (comment: 01825_type_json_in_other_types.sh) (query 1, line 2) (in query: SELECT (data.2)['aa'] AS aa, (data.2)['bb'] AS bb FROM t_json_nested ORDER BY id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:39.395835 [ 29256 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT (data.2)['aa'] AS aa, (data.2)['bb'] AS bb FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:39.824112 [ 10341 ] {3bfa3cfb-5a6d-4dd6-868d-ca609e51269e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope WITH (data.2)['aa'] AS aa, (data.2)['bb'] AS bb SELECT tupleElement(aa, 'k1') AS k1, tupleElement(aa, 'k4') AS k4 FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51798) (comment: 01825_type_json_in_other_types.sh) (query 1, line 2) (in query: WITH (data.2)['aa'] AS aa, (data.2)['bb'] AS bb SELECT tupleElement(aa, 'k1') AS k1, tupleElement(aa, 'k4') AS k4 FROM t_json_nested ORDER BY id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:39.854333 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope WITH (data.2)['aa'] AS aa, (data.2)['bb'] AS bb SELECT tupleElement(aa, 'k1') AS k1, tupleElement(aa, 'k4') AS k4 FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:39.908134 [ 5105 ] {e3cec656-c0c3-4029-92ef-41acbc9e47ae} PushingToViews: Failed to push block to view test_7.view_4 (bbc12e71-369b-47e4-8956-8a6a6b1ca48c), Target table 'test_7.`.inner_id.bbc12e71-369b-47e4-8956-8a6a6b1ca48c`' of view 'test_7.view_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.07.13 02:31:40.039667 [ 5105 ] {e3cec656-c0c3-4029-92ef-41acbc9e47ae} executeQuery: Code: 60. DB::Exception: Target table 'test_7.`.inner_id.bbc12e71-369b-47e4-8956-8a6a6b1ca48c`' of view 'test_7.view_4' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51774) (comment: 02965_projection_with_partition_pruning.sql) (query 3, line 5) (in query: insert into a values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./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) @ 0x0000000031efbeaf 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:40.075440 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Target table 'test_7.`.inner_id.bbc12e71-369b-47e4-8956-8a6a6b1ca48c`' of view 'test_7.view_4' 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./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) @ 0x0000000031efbeaf 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:40.366192 [ 6022 ] {89f7e047-924e-4b44-b1d6-38b77e75f59c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT data.3 AS obj FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51830) (comment: 01825_type_json_in_other_types.sh) (query 1, line 1) (in query: SELECT data.3 AS obj FROM t_json_nested ORDER BY id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:40.375076 [ 6022 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_nested' in scope SELECT data.3 AS obj FROM t_json_nested ORDER BY id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:31:40.916103 [ 3815 ] {38727b10-2ecb-4a96-8fd4-1274d5e8b731} executeQuery: Code: 57. DB::Exception: Table test_r2s0xout.sparse_tuple already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39874) (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 = 47285, min_bytes_for_wide_part = 1073741824, 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 = 388363679, compact_parts_max_granules_to_buffer = 150, compact_parts_merge_max_bytes_to_prefetch_part = 20942449, merge_max_block_size = 15008, old_parts_lifetime = 244., prefer_fetch_merged_part_size_threshold = 1707361573, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 46, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 27157979, 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 = 35530, primary_key_compress_block_size = 71227, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:40.922960 [ 3815 ] {} TCPHandler: Code: 57. DB::Exception: Table test_r2s0xout.sparse_tuple already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:41.233859 [ 34277 ] {b23edda5-5c17-4807-851a-4ad31301ef78} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 377, line 126) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:41.265649 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:42.587811 [ 46294 ] {8c986ad8-0366-427f-8179-032ab3220b1b} executeQuery: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number ASC. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51988) (comment: 02293_grouping_function_group_by.sql) (query 2, line 3) (in query: SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:182: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca5d65 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cca4722 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc06700 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:31:42.603206 [ 46294 ] {} TCPHandler: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number ASC. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:182: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca5d65 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cca4722 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc06700 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:31:43.003736 [ 34259 ] {a575d7d2-5958-49fe-8d9e-b641562bcf0d} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52024) (comment: 01762_deltasumtimestamp_datetime64.sh) (query 1, line 1) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002458f667 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:43.031898 [ 34259 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002458f667 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:44.571317 [ 46286 ] {083b493f-b82c-4ca3-96a2-d8ad81d53fc7} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52074) (comment: 03247_generic_arrayMin_arrayMax_fixes.sql) (query 7, line 14) (in query: CREATE TABLE test_aggregation_array (`x` Array(Int)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 20791, 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 = 0, compact_parts_max_bytes_to_buffer = 443892651, compact_parts_max_granules_to_buffer = 75, compact_parts_merge_max_bytes_to_prefetch_part = 18210325, merge_max_block_size = 5203, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5725022344, index_granularity_bytes = 13724643, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 18962, primary_key_compress_block_size = 69177, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:44.584719 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:44.844076 [ 6024 ] {5acb38bd-3b28-4d00-a669-7aead7784a1c} executeQuery: Code: 57. DB::Exception: Table test_7.data2013 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52172) (comment: 00098_e_union_all.sql) (query 3, line 4) (in query: CREATE TABLE data2013 (name String, value UInt32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:44.862615 [ 6024 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.data2013 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:45.084422 [ 36814 ] {} ExternalDictionariesLoader: Could not update external dictionary 'adb3a69b-030c-4b63-bb50-b4df8179f999', leaving the previous version, next update is scheduled at 2025-07-13 02:31:50: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/4a0/4a09969d-ef53-4204-9471-eaf2382d2104/all_1_1_0/data.bin (position: 162, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: c1ad0adfd291e49999f512ed090ec82d822600000024000000): (while reading column c): (while reading from part /var/lib/clickhouse/store/4a0/4a09969d-ef53-4204-9471-eaf2382d2104/all_1_1_0/ in table test_lzxzicyb.t1 (4a09969d-ef53-4204-9471-eaf2382d2104) located on disk default of type local, from mark 0 with max_rows_to_read = 4): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e75622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b298ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7f0c 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 17. DB::ReadBuffer::next() @ 0x0000000017e75832 18. ./src/IO/ReadBuffer.h:96: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c6729d7 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:46.211292 [ 34340 ] {} TCPHandler: Code: 394. DB::Exception: Query '199d01db-c733-4981-b506-976d97eb24fd' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2b012b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.754501 [ 10341 ] {a60db4d5-37bf-4b0f-b807-a67d749887d9} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52304) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.778170 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.799747 [ 5382 ] {7d686435-37cf-411d-bb98-ae7c776e0cc9} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52272) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.806564 [ 5105 ] {df2912f2-bfe1-457d-8990-5241327a190b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52292) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.814173 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.843321 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.853222 [ 6126 ] {ffcdbc15-ded8-4f30-a81d-0c1ac63b8b77} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52288) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.868490 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.953136 [ 5380 ] {acafe253-03b9-4c70-b4be-caf79fa6c677} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52262) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.976789 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:46.990301 [ 34260 ] {25e9ed39-a6b6-4799-8b65-1283a6dc33ac} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52332) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.007305 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.023955 [ 34259 ] {dadccedf-1758-452d-ae71-d019dad0e41a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52362) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.024193 [ 5826 ] {f16e7412-2980-47f8-aea7-7a7cfb467f5c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52340) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.027522 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.047450 [ 5072 ] {c2557a5f-cfd9-48b0-8c0a-050e93311fe5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.047755 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.061846 [ 5072 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.069753 [ 32979 ] {006965df-d292-4493-ba12-8271e9ed5543} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52318) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.084198 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.089613 [ 34340 ] {288a963f-fc7f-40d8-9d14-797ee94ab089} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52400) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&) @ 0x0000000020f10c2f 5. DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f18a0b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb194ab 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x000000002cb1a20a 15. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb86a70 16. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7bd4c 17. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb99f84 18. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002de09817 19. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a4fb 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.149292 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&) @ 0x0000000020f10c2f 5. DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f18a0b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb194ab 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x000000002cb1a20a 15. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb86a70 16. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7bd4c 17. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb99f84 18. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002de09817 19. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a4fb 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.198277 [ 3766 ] {64bc62c7-5a91-45a4-9301-78a42d9e0f8f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52366) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.198349 [ 34273 ] {2d349a4a-0345-46a6-834f-778ed4d75ed0} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52352) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.209108 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.217210 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.247498 [ 5826 ] {b3845386-6440-43bd-9eaa-84be938978f8} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52420) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.253576 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.257651 [ 5072 ] {6e9fc603-4081-4b4e-ae52-bbceb35634dd} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52424) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.271547 [ 5072 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.531507 [ 5826 ] {1c5e40a1-b31d-4991-a3d7-b196dc136e2b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52462) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.531813 [ 46286 ] {afb018cd-002b-44e0-a3f2-6fc17b0eacef} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52438) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.533136 [ 34340 ] {1cc16965-279c-45f3-8fb6-9278e3edbafd} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52450) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.546313 [ 3815 ] {15b6e730-98a8-4d90-89d9-3c0fcda42d06} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52476) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.546433 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.546661 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.560429 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.562515 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.578218 [ 6126 ] {15149c96-a1e5-4ddf-bccb-52949e9ef86d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52492) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.609530 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.689011 [ 5105 ] {023147c7-3485-4f18-adaf-9d099d36b087} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52496) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.717775 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.919414 [ 46286 ] {e25aff3e-61d0-4b5f-b942-1020d319315b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.928393 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.972109 [ 3815 ] {530c6e1c-0eb6-43e8-b191-96a6bafc8795} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52536) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.972638 [ 5826 ] {a186d646-f5a5-432e-9639-e7b13bbfb2ef} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52530) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.977873 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:47.978581 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.009961 [ 5382 ] {241d87d9-e7e9-4162-97d1-ed9a7c7795de} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52554) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.015874 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.044086 [ 5380 ] {0914aff4-d6f4-478c-b43a-32e53d12f87a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52548) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.059397 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.113346 [ 6126 ] {9ac3edf7-7319-49a4-bdd6-a0d3bebd6af0} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52558) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.120731 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.177535 [ 32979 ] {fdb3cd45-652b-4dc6-b27a-374214636bde} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52584) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.193272 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.285331 [ 3816 ] {b5cf63a8-9b8b-434a-bb42-4f911b75f173} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52598) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.296328 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.313864 [ 5826 ] {4ef29d53-67a6-463c-8c23-3976ee351719} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52614) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.315156 [ 3815 ] {28215354-6ecd-4183-bbe4-d63057b641fb} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52626) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.344814 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.345689 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.433471 [ 46294 ] {3af81ff8-0837-4465-9d5b-c48824a9f34f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:51988) (comment: 02293_grouping_function_group_by.sql) (query 10, line 89) (in query: SELECT number, grouping(number, number % 2) as gr FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY CUBE(number, number % 2) WITH TOTALS HAVING grouping(number) != 0 ORDER BY number, gr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5462: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0803d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.441845 [ 46294 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5462: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0803d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.457410 [ 5105 ] {bf761935-9d98-4333-8274-02f8fe3aed72} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52664) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.469960 [ 34260 ] {9cfc2c44-b775-430e-9791-4e816c83baa9} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52680) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.508778 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.508967 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.574465 [ 5380 ] {d710b81f-0406-4e9a-afb2-4a214af47c39} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52642) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.588498 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.616971 [ 46285 ] {032e2d25-942c-4b17-ae29-3e2e938b704e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.622082 [ 5826 ] {c5a50bb8-91a1-4c45-8426-6cbb56539d34} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52728) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.628805 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.648302 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.677966 [ 3815 ] {9537b04d-74cb-4f4d-aea5-a778ce642bf6} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52732) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.700913 [ 34259 ] {4d838c37-a926-4eb5-bb0f-420fb1e99b80} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52700) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.713038 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.726325 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.790586 [ 5105 ] {82e50ee1-9939-4042-bf06-a68e0bf742c6} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52756) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.795859 [ 2824 ] {aafc4518-0b77-4497-9ff6-119263c3ce20} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52748) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.800729 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.810732 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.920211 [ 5826 ] {a054a8c1-165a-4605-9de7-ee417f095c1d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33490) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.924103 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.955142 [ 3815 ] {61ef5338-b24c-4050-8a57-2bacdc30d375} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33510) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.974334 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:48.988670 [ 5380 ] {a4882a8c-7184-4cb3-9117-53ce0f10b5fd} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33494) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.005205 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.043458 [ 5105 ] {c6d0063d-d672-4b1f-b829-44df1b377471} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33512) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.065323 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.175293 [ 5826 ] {27805aa1-830d-4e68-98fd-bcd43599d718} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33536) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.180489 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.201595 [ 46294 ] {8cd54bd0-d14e-4c75-9991-71202c752d22} 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.3.20372.altinityantalya (altinity build)) (from [::1]:51988) (comment: 02293_grouping_function_group_by.sql) (query 12, line 109) (in query: SELECT number, grouping(number, number % 2) as gr FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY ROLLUP(number, number % 2) WITH TOTALS HAVING grouping(number) != 0 ORDER BY number, gr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5462: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0803d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.203815 [ 46294 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5462: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0803d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.737363 [ 34273 ] {606ef963-3ac8-4e20-adb5-2fe69a1713d3} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33566) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.747063 [ 3766 ] {31d5688f-1457-4a88-a3b2-233f166e3a81} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33618) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.747998 [ 5072 ] {18fd1694-2265-460b-8421-683e9ebb93d1} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33628) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.749924 [ 34260 ] {e8126eef-53b1-497c-8984-93683bd8bbe8} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33594) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.750014 [ 34259 ] {7e244337-7134-4119-8f3a-fda86b773af2} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33606) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.800292 [ 5826 ] {bd6052e7-8ab2-4e5e-8113-f868eab9aab7} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33580) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.823133 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.832794 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.840431 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.849311 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.849561 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.868186 [ 6126 ] {df146828-ed71-4d85-8c01-1306c947e11e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33670) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.869015 [ 34340 ] {882f993a-09ee-475a-acae-5b7d2178c32c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33648) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.876695 [ 5072 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.900631 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.900715 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.956070 [ 34277 ] {400a23fa-6bce-48a1-b2fa-ec790f575a19} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 416, line 139) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.961366 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.965117 [ 3816 ] {27b4ac68-1b7b-4327-9e4a-badecc71b209} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33662) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.975172 [ 2824 ] {1bcad109-d2a1-4008-bc87-91be2a76acbf} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33626) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.984430 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.990160 [ 10341 ] {3a70aaa8-b13c-49d8-8925-5b63f6cc44d7} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33682) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:49.986529 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.002606 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.312104 [ 10341 ] {fad69532-f8b9-40ca-8ea2-a2ffb62eb392} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.316206 [ 46286 ] {1ae9f032-42c1-42ef-ac50-701252d48fce} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33704) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.324822 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.337694 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.341929 [ 5826 ] {605a02ed-015e-4ab8-b940-65a6209f06a9} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33726) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.343528 [ 3816 ] {1c1e74c4-84ec-4ced-84a9-ba2541f308e0} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33708) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.353666 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.355529 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.417589 [ 32979 ] {3f2ff21b-282d-4ddf-bdab-a30935c4174b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33746) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.434282 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.494933 [ 34340 ] {4fe824da-86db-4ca3-b450-f52007bc7495} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33752) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.496462 [ 5105 ] {a93f5a93-5969-460e-a241-0598a5355653} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33774) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.498423 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.507793 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.637302 [ 3815 ] {1aec8516-074b-438d-a8c8-d13ad54b7473} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33766) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.652945 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.653576 [ 6024 ] {e333f274-4a51-474b-ba15-7d7ce2498d44} executeQuery: Code: 57. DB::Exception: Table test_l7ai5wmo.t_ephemeral_02205_1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52518) (comment: 02205_ephemeral_1.sql) (query 22, line 44) (in query: # Test without default CREATE TABLE t_ephemeral_02205_1 (x UInt32 DEFAULT y, y UInt32 EPHEMERAL, z UInt32 DEFAULT 5) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.661418 [ 6024 ] {} TCPHandler: Code: 57. DB::Exception: Table test_l7ai5wmo.t_ephemeral_02205_1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.698402 [ 34340 ] {be57a4cb-9828-4c4d-9123-31bb8302c430} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33792) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.749602 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.754556 [ 6126 ] {a46e7877-f0eb-4c65-96e3-52f9afc94c8f} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33808) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.780711 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.889819 [ 10341 ] {1a42378b-b99d-41e4-b1c9-3bc23879f97b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33816) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.910942 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.950586 [ 32979 ] {0ea44f6f-a3c6-4c50-af7f-5d2df45b97a4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33824) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:50.965370 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.001708 [ 5826 ] {e1f36253-cfb4-4e5e-a654-ab7996fc383b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33830) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.009841 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.057565 [ 46286 ] {ecd79023-fc70-4d84-a60a-e2466f26abdf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48768) (comment: 01798_uniq_theta_union_intersect_not.sql) (in query: DROP DATABASE IF EXISTS test_vh5zu6uj SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.060294 [ 46286 ] {ecd79023-fc70-4d84-a60a-e2466f26abdf} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:51.064174 [ 34260 ] {1435ee46-e88a-4506-9e58-4438a5131c7e} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33860) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.079443 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.108377 [ 34340 ] {d1be5f9c-2bb1-4d42-986c-f94ab6346c90} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33866) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.113605 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.208359 [ 3816 ] {a7cf3f70-ac74-492f-a958-fc77d30c99a2} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33868) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.222506 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.296776 [ 34259 ] {e4d23307-1196-4200-bbb9-20e5eb51ce2e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33900) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.304621 [ 10341 ] {28a16c44-9ae3-4a28-8046-f2c9253a6d77} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33898) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.311783 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.323512 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.387231 [ 3766 ] {72a84d84-30d4-4374-bfd1-973dadf3170c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33928) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.396035 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.412315 [ 32979 ] {e5ed8373-0873-4083-9fcd-224e9ec2157a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33948) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.516397 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.597223 [ 6024 ] {24f34f35-1c5b-4885-9e76-2192fbd8dc10} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33956) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.597531 [ 2824 ] {ab910171-9164-418a-9b4e-343b4e63e86d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33934) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.616421 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.618723 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.763270 [ 46286 ] {caab4993-30a1-46b4-8b28-5231b14a8a4e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34032) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.781892 [ 32979 ] {0b900755-9660-4dc4-a96e-56e98e02da73} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34018) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.782322 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.783527 [ 34259 ] {81cd7411-5f9d-43e4-83c1-16afeea3f315} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48780) (comment: 02234_column_function_short_circuit.sql) (in query: DROP DATABASE IF EXISTS test_wytez3u4 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.785168 [ 34259 ] {81cd7411-5f9d-43e4-83c1-16afeea3f315} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:51.795685 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.800903 [ 34340 ] {02120ed2-4884-4f5f-8c19-3741da689c31} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34046) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.812150 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.830673 [ 6022 ] {4a5524d6-15bc-46c1-a46b-661c46313af5} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34006) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.835658 [ 3766 ] {0bd4c9d6-5bee-4bdb-8b28-fff125381d25} 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.3.20372.altinityantalya (altinity build)) (from [::1]:33998) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.836952 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.868234 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.884442 [ 46285 ] {0d1a0b19-0a1e-43cd-a5f5-59a3f1b4c76a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34062) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.900178 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:51.969930 [ 3816 ] {470a6eca-507c-419f-9b18-2a6b1877f328} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34054) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.055540 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.122935 [ 34273 ] {545de129-301b-44a8-bfbc-adec698e90cc} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34080) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.136965 [ 6022 ] {dfc55e82-4fc5-4005-82cd-4f13ba1ccef4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34084) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.164434 [ 46285 ] {1cf7f2ea-d2e8-4201-a795-c9f49f6a9a72} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34106) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.186865 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.187949 [ 6022 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.214737 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.221941 [ 2824 ] {0e294bbb-6eba-4306-a4af-88ee9cfac40c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34110) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.233843 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.327350 [ 46286 ] {41195ff0-050c-44cd-81da-5c2e8eeb196a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34124) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.332326 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.354868 [ 6024 ] {8d5b6068-a82b-4a7b-b045-9b039852da5d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34146) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.368538 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.368930 [ 46294 ] {cb3f15cf-1375-4ff3-b5ce-a96378093a44} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34116) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.388368 [ 46294 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.515169 [ 3815 ] {bddc726b-6822-45b6-8181-293ed64ca285} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34170) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.515229 [ 3816 ] {c2e7845d-c54f-4ddf-be12-a5b5a46fa291} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34156) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.528087 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.528180 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.665510 [ 5382 ] {e4ab44c4-e5b4-4b49-8fe9-1647b14f2bcd} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34196) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.678267 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.678688 [ 5380 ] {b419ca13-ee39-40bc-8848-cc924f2ebcf4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34182) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.688316 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.850373 [ 3816 ] {18d5a7f8-a1ea-4996-9b10-96f67acbe2bd} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34214) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.855842 [ 46282 ] {3fdc5dfe-6b27-4adf-86e3-0b0fd28c8a53} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34234) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.864495 [ 32979 ] {3fc9497e-6d78-4113-9fec-7266aec57c16} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34244) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.870262 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.893992 [ 5382 ] {167e2790-7884-497d-8eda-6d3d26c2bd6e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34256) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.912591 [ 46282 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.923688 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:52.933078 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.046620 [ 34277 ] {aec8a816-7792-4193-925d-32e90cc3cf69} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 431, line 144) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.062305 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.091174 [ 5105 ] {01423a5e-a698-4bff-9ec7-028ab59a3c3d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34282) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.104827 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.134885 [ 5380 ] {753d82a0-bb76-4998-9b6e-395ca27b3c99} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34266) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.135438 [ 34260 ] {baeaa8ce-cf30-4f62-bca1-3b6fe65220e5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34292) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.166585 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.167999 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.226869 [ 3816 ] {c270d240-d0f1-4613-aa71-b3a2d48a5f7e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34278) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.242477 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.245420 [ 5382 ] {efda601c-c85c-45af-946b-d81b9893a750} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34286) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.246510 [ 32979 ] {11ca6b73-656b-4fe0-98e9-6a1e486ed75e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34314) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.273713 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.273852 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.351706 [ 46285 ] {0c413e31-f1a5-4799-b89d-c8a9b26e8d6b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34346) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.353702 [ 34259 ] {1a7a3108-4b88-4354-bfc4-66b0fd134ad5} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34320) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.353838 [ 5105 ] {5fef7acb-2779-43a1-b7f4-f522aef2a440} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34328) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.357655 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.364326 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.365750 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.367528 [ 34260 ] {d2a1e9e0-09aa-4c5e-9ff0-492273b0544a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34334) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.380355 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.561000 [ 34273 ] {6811189f-01e0-466b-82d4-fbdaed1dac99} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35460) (comment: 00224_shard_distributed_aggregation_memory_efficient_and_overflows.sql) (query 3, line 6) (in query: SELECT count() = 200000 AS `equals(count(), 200000)` FROM `test_j9i96hv9`.`numbers_100k_log` AS `__table1` GROUP BY `__table1`.`number` WITH TOTALS ORDER BY `__table1`.`number` ASC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.561813 [ 3816 ] {3bf9ca91-ec14-45db-996f-0f1a4eb1906a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48842) (comment: 00816_long_concurrent_alter_column.sh) (in query: DROP DATABASE IF EXISTS test_vgc65qvu SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.563433 [ 3816 ] {3bf9ca91-ec14-45db-996f-0f1a4eb1906a} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:53.566943 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.569141 [ 5380 ] {eeb22fc4-5910-43d0-8961-564de59bd969} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34352) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.584138 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.584555 [ 34260 ] {d3af7c8b-1586-4a53-8103-3647f73c9b90} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34362) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.589846 [ 5826 ] {c5975cfb-f3f4-43d5-b515-a8598eb469e1} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34164) (comment: 00224_shard_distributed_aggregation_memory_efficient_and_overflows.sql) (query 3, line 6) (in query: SELECT count() = 200000 FROM remote('127.0.0.{2,3}', currentDatabase(), numbers_100k_log) GROUP BY number WITH TOTALS ORDER BY number LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:31:53.589999 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.621937 [ 5826 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.640316 [ 46282 ] {6269fdfb-d4d3-4260-93f7-a2db4adabdd2} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34368) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.651062 [ 5382 ] {c5038c13-cb4c-4859-966e-9308dfdbf83d} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55636). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:53.657462 [ 46282 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.754043 [ 5382 ] {c5038c13-cb4c-4859-966e-9308dfdbf83d} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55636). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55636) (comment: 00224_shard_distributed_aggregation_memory_efficient_and_overflows.sql) (query 3, line 6) (in query: SELECT count() = 200000 AS `equals(count(), 200000)` FROM `test_j9i96hv9`.`numbers_100k_log` AS `__table1` GROUP BY `__table1`.`number` WITH TOTALS ORDER BY `__table1`.`number` ASC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.825483 [ 5382 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55636). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.832256 [ 32979 ] {8365e7c9-be76-48b5-bba4-dc7d3a00a2c3} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34384) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.843334 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.845809 [ 34273 ] {8adac649-9359-48d5-966e-4b0a16d1982d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34398) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.846019 [ 3816 ] {cd771fe4-118c-49ee-acc1-415f339f9474} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34374) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.847619 [ 46285 ] {8300575a-4360-4c92-ad0c-f81cb5171b22} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34412) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.861063 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.873577 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.875082 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.903548 [ 6024 ] {90ebfd59-f125-44a3-a3f8-afd9659ff12b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34426) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:53.930189 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.050758 [ 3816 ] {e88c3492-3eda-4d9d-b4f8-ad6e934fce9d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.090319 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.109298 [ 2824 ] {7208a7cf-8920-49f3-b705-1cd2230b2a3c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34442) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.121347 [ 32979 ] {8940bfe5-3e3d-482d-bb26-9d925a8fd262} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34470) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.134606 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.138106 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.233328 [ 3816 ] {6b89e0f1-fd4c-421e-83d5-3c130683ddfc} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34496) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.242623 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.382977 [ 6024 ] {58270e85-0ba6-4ced-b9f1-e0b06bc3f53b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34500) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.384206 [ 46285 ] {f84fc8a6-b821-4ca8-98fc-4d39d0b1f49b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34492) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.394309 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.404636 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.429585 [ 34340 ] {a3fb7518-3ae7-43d9-aad6-2d848939c74a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34546) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.447837 [ 3816 ] {36a13975-dc97-46ca-a86c-c75dfdf4c9c2} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34548) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.455269 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.465571 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.476963 [ 32979 ] {2edfbfd1-416d-40c3-a227-2ebfac0cb000} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34534) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.486035 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.487737 [ 6126 ] {7398df9e-81bf-4bb2-aefb-f011f7fcbada} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34558) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.506746 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.567817 [ 3766 ] {24757790-d244-494a-9578-2406c2199b48} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34582) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.593259 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.608364 [ 5476 ] {de7f3ddc-d323-4878-8680-3cfc59878f6d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34574) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.631642 [ 5476 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.663993 [ 46286 ] {2fc39a7b-38a3-4014-918a-7c56559a80ce} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34536) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.664959 [ 2824 ] {a2ec11b2-f936-46e2-9370-1855c8ab1704} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function deltaSumTimestamp, this type is not supported. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34510) (comment: 03272_bad_aggregate_function.sql) (query 1, line 1) (in query: SELECT deltaSumTimestamp(1, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:244: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002458f445 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.672074 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.690835 [ 2824 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function deltaSumTimestamp, this type is not supported. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:244: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002458f445 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.833888 [ 32979 ] {047ad3b8-8a21-45af-a3f8-82238924de54} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34602) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.839839 [ 3816 ] {4ec31de2-e640-4a4b-baa6-639c258610cd} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34588) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.862373 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.900043 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.973479 [ 2824 ] {8d5ca9b0-4d1f-4150-823a-7b083e218904} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34616) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.993251 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:54.993870 [ 6024 ] {fecb06d7-e67a-48ac-8ac5-677d6cd7c57d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34626) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.020595 [ 46286 ] {7f2fb361-2907-4c61-ba71-c461dfdb66cc} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34632) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.023334 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.031347 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.059000 [ 34340 ] {a3ec27ec-2a5b-44b3-a84b-1b37fa834432} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34648) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.084815 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.100545 [ 6126 ] {22ebc1bb-a897-4c71-8f6c-0debbe6efa38} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34660) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.116992 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.176024 [ 46286 ] {880ce844-8985-4b8c-953b-fb0b81f76a4a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48954) (comment: 02915_analyzer_fuzz_2.sql) (in query: DROP DATABASE IF EXISTS test_f7tbuqto SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.178556 [ 46286 ] {880ce844-8985-4b8c-953b-fb0b81f76a4a} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:55.296156 [ 6126 ] {042a833e-d06a-40e9-91b0-6b91572245a4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34672) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.309659 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.328664 [ 46286 ] {40ebab0b-ffaa-49dc-a55c-0a349b6a50a1} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34684) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.344641 [ 46286 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.434189 [ 5826 ] {77d95097-ac07-4cd3-95c7-75af75568406} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34700) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.440688 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.454474 [ 5382 ] {c99d12c4-e1b4-473a-9cc2-23e32580f1aa} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34686) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.475681 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.489883 [ 5476 ] {39262e31-e655-42cd-adda-a63aab160ac1} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34664) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.503760 [ 5476 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.546191 [ 46286 ] {b7751e0e-2212-4a7d-9bf0-089d70bf372e} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34702) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.558645 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.633869 [ 6126 ] {f42ee655-7ee6-4d7b-9565-6f80ba60e2ac} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34712) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.640865 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.719304 [ 5826 ] {61d6316a-7dc8-498a-8c6d-a89140229a82} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34748) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.723148 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.764558 [ 3766 ] {b7cc5245-9ed4-4d9c-8084-ce24e87774f4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34732) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.782908 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.855608 [ 5382 ] {005e8f06-e699-4d52-af65-e54785974904} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34764) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.874385 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.885744 [ 5105 ] {99e8a2ae-7571-4ddb-a61a-7c0d16423b3e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34784) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.914470 [ 6126 ] {680044c1-3bb7-4523-91ce-d968fbf83845} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34778) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.949136 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.983519 [ 34260 ] {822aed92-9444-4335-96f6-532cb05470d5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34796) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:55.997676 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.001546 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.029814 [ 10341 ] {20cbf6fe-3dd9-4d6d-b995-182c64c51855} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34808) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.096909 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.172882 [ 46282 ] {10153a76-1a24-43bb-8727-b936638c8a72} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34802) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.192541 [ 46282 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.344466 [ 6126 ] {da5e483a-7f27-4ade-a3e9-c56380cc807e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34838) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.347692 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.365276 [ 34340 ] {7d27c665-9d05-4332-bf4b-5f5c55223f0c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34824) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.384026 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.432297 [ 5380 ] {4f83e4da-d2de-47d6-aacb-7deba00198a4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34846) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.462226 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.525875 [ 5105 ] {57ab6085-c62c-4b00-86bb-e54719488dfa} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34872) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.530937 [ 34260 ] {3c53a443-f793-42e5-ba09-cb0a824c5d17} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34884) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.533794 [ 46282 ] {9f2b9eec-d926-4b18-bd57-17c900a97616} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34886) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.546372 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.553147 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.553702 [ 46282 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.652686 [ 5382 ] {6526de64-adc9-4aa5-99da-2b290b4349eb} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34860) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.664685 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.680679 [ 5105 ] {bd0756c8-6ef3-464e-8fa1-45cf4e1295f6} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34900) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.689917 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.756516 [ 34260 ] {d23e8183-bacc-48b1-98eb-4e6da4704ae8} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34908) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.767442 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.943198 [ 5105 ] {9abe737f-f6e4-42d7-8ac5-478a48b116d6} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34922) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.956049 [ 5382 ] {d6ffc52b-a9d6-4881-92f5-c82689749a30} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34914) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.956802 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:56.975476 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.214506 [ 3816 ] {9b550eab-1cb8-47f9-ac52-8ff0e6f44fd5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34952) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.216408 [ 10341 ] {55597592-021b-4b8f-ab05-8ca740d75ac5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34930) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.229699 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.229813 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.233834 [ 34260 ] {ebea5f16-9c5c-490f-b2fc-4dd21389dac5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34928) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.248460 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.265358 [ 34273 ] {ad20cd75-6f60-4019-8d03-d0344e3cbde9} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34976) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.286321 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.299673 [ 6024 ] {38e3fb34-6edb-4775-b003-f553283ba9db} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35020) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.314268 [ 6024 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.396606 [ 2824 ] {fadd1861-ae5d-4f89-9232-83db931bbf60} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35010) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.417545 [ 2824 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.427981 [ 5105 ] {e3d8f7fa-4329-4a73-b47a-90833ffbb0e4} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35000) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.431334 [ 6022 ] {e9140091-e642-46cb-8821-5ed9e42c778f} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35042) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.432157 [ 46294 ] {1c48dd2b-3e06-43b4-81ac-acec1196eff9} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35032) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.442852 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.460048 [ 46294 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.468561 [ 6022 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.490032 [ 5382 ] {e629303a-c4f5-4118-b609-47e39a047734} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35028) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.517974 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.634173 [ 5105 ] {68f1181a-e463-462d-8009-53384b4f0560} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35046) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.724893 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.812970 [ 34260 ] {fae80b65-017a-47e5-9ad5-7b4b1ebf8927} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35054) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.815039 [ 5382 ] {968104ec-b24c-4a3a-8cf4-bf403afb0285} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35068) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.826276 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.835810 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.965992 [ 10341 ] {34fede4f-7883-4e96-a105-932e54f0948e} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35074) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:57.973982 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.108437 [ 46294 ] {b3bf7f76-9147-4bf8-bcc6-29ce894fe9eb} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35118) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.110914 [ 46285 ] {f5cbe66d-c489-4995-84a1-b8dc6ed1ee95} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35098) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.112286 [ 2824 ] {b68ef9ce-20d4-4a00-adac-c9f4d28c511d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35102) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.116292 [ 46294 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.135409 [ 5105 ] {93bb4d68-8d0b-4e1d-8a03-4e3ea0126ee4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35134) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.135542 [ 46285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.156390 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.166115 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.191518 [ 34273 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.196776 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.316588 [ 6024 ] {4c64fb8d-03b7-4a19-8986-0a0d26e4fd07} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35106) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.338276 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.434682 [ 34260 ] {f3dcdff0-2f7b-4f00-bd8f-37af86732db2} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35146) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.436305 [ 5382 ] {ce6c64e3-6fef-4d56-8adb-f299155b2665} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35142) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.444567 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.453249 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.463146 [ 6022 ] {e8606f39-9ba8-4a49-a32e-a1232f3091f1} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35164) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.474786 [ 6022 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.483665 [ 10341 ] {bbef5924-63e1-4bb4-9536-bd27ed4fcaf8} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35162) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.509702 [ 10341 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.536392 [ 34340 ] {4698f6bc-9de4-490f-b595-d7ec6f29af40} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35190) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.547957 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.578734 [ 3815 ] {a98a7d06-d90b-45c7-aaab-b30d07884ea1} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35174) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.614410 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.637429 [ 34260 ] {bb9398cf-fddf-4507-81f7-de75ad00a601} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35220) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.652034 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.678727 [ 5382 ] {a5d0ed5e-2b2d-49d0-bf59-6083141e2ad5} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35206) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.689361 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.777518 [ 6022 ] {d1d5c8ed-7322-449a-8bd5-530d1b785950} 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.3.20372.altinityantalya (altinity build)) (from [::1]:35230) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.798329 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.828286 [ 34260 ] {4f85c3b8-703f-48e7-817e-957206d6f251} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54284) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.830947 [ 3815 ] {54b760a5-3cdc-4ae1-9b7f-7c26ee944f03} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54288) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.841662 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.846835 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.860993 [ 5382 ] {7899d18a-4e6c-41d5-b693-017082c919ba} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54292) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.881530 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.885989 [ 34340 ] {b79fea2a-92f0-4ead-810e-8897146d26ea} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54290) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.896636 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.922493 [ 3766 ] {bd074868-27bb-4f7a-9333-6c977fabb509} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54308) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.961374 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.966394 [ 5380 ] {b9d081af-08f0-49b5-a60f-b38d49ef7b82} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54310) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.987499 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:58.988333 [ 5476 ] {5058756c-45e1-4812-83cf-ac66672528f8} executeQuery: Code: 43. DB::Exception: Invalid origin H3 index: 37480377652084735: In scope SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34726) (comment: 02292_h3_unidirectional_funcs.sql) (query 19, line 26) (in query: SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionH3GetUnidirectionalEdge::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c15a8c0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:31:58.998295 [ 5476 ] {} TCPHandler: Code: 43. DB::Exception: Invalid origin H3 index: 37480377652084735: In scope SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionH3GetUnidirectionalEdge::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c15a8c0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:31:59.269299 [ 5382 ] {8138b58a-8498-4050-b694-4f0b046ccb83} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54326) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.274360 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.358460 [ 34260 ] {191174c8-a71a-4f9a-aff4-cec3efa45cc1} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54334) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.388319 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.418153 [ 3815 ] {622e431b-e4ce-4ceb-8fd6-2ecdbffc69a6} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54350) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.426015 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.441060 [ 5380 ] {56b421ba-8aa0-4a49-8065-23350685b125} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54382) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.452962 [ 3766 ] {3ca0be0d-7d5c-41d5-9b1b-33574f0419c0} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54368) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.472299 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.473576 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.476659 [ 34259 ] {83c57ed4-c60a-4e4d-a053-2cc83009fa18} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54392) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.501871 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.512052 [ 5105 ] {381be5f4-4f83-4cc1-9087-d80971a48f1f} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54396) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.520640 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.527245 [ 5382 ] {a3e11c8f-8422-4d7b-8778-4120d425263b} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54410) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.531587 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.679570 [ 34260 ] {3ae19ce0-9089-4fe3-a909-3eab617c5b3c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54418) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.700152 [ 34260 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.841480 [ 3766 ] {afebfaa1-f090-43e3-bb8c-223396f86008} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54432) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.841677 [ 5380 ] {07c906ac-0cc9-4939-88c6-0461e19c3da3} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54446) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.845383 [ 3766 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.856102 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.870526 [ 5105 ] {24030efb-8675-4172-a97e-d2d12711fc9d} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54462) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.885840 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.905124 [ 5382 ] {d64acdd4-ba80-4bff-8d7a-b587ed2505b6} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54420) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.920215 [ 34259 ] {13f03daa-0d7b-4681-8e1f-b10eafa10760} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54460) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.924693 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.931084 [ 3815 ] {c1a527bf-6f1e-49bc-85ec-0fcf1ddfc116} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54424) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.941771 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:31:59.956663 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.137661 [ 5380 ] {03556b96-17a5-47a9-8d49-1c6959fbb456} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54482) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.153032 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.167804 [ 3815 ] {5c49b46a-aee3-4e50-80cd-fba3563f71fe} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54528) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.176640 [ 3816 ] {c6c184b0-89d8-4cc0-9766-eb495c991895} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54514) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.195860 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.198433 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.204912 [ 5105 ] {85fc71e0-dce7-4b5e-912b-582cb4c8f460} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54498) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.217167 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.320723 [ 32979 ] {24badc4c-acbe-4196-9b18-03fbdf308762} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54542) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.331375 [ 34259 ] {ee9fa96c-2ba3-47a4-a7e0-364fccf59157} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54540) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.342824 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.340303 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.371022 [ 5380 ] {e14846d9-36e1-4e8c-92b1-f9487c486417} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54558) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.383309 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.391011 [ 46282 ] {c9dd2aec-1a7d-44ca-a162-423b18c25429} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_fiykc306.t1' in scope SELECT id FROM test_fiykc306.t1: While processing conversation IN (SELECT id FROM test_fiykc306.t1). (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34944) (comment: 02841_not_ready_set_constraints.sql) (query 9, line 23) (in query: INSERT INTO t2(conversation) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1464: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6aafd5 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d69f716 14. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 15. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 18. ./build_docker/./src/Storages/ConstraintsDescription.cpp:146: DB::ConstraintsDescription::getExpressions(std::shared_ptr, DB::NamesAndTypesList const&) const @ 0x0000000030303066 19. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:34: DB::CheckConstraintsTransform::CheckConstraintsTransform(DB::StorageID const&, DB::Block const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x0000000031da91a7 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::Block const&, DB::ConstraintsDescription&, std::shared_ptr&) @ 0x000000002dcf7c92 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::Block const&, DB::ConstraintsDescription&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::Block const&, DB::ConstraintsDescription&, std::shared_ptr&) @ 0x000000002dcf7aae 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::InterpreterInsertQuery::buildPreSinkChain(DB::Block const&, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002dce97e9 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:511: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceaf0f 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:32:00.406513 [ 46282 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_fiykc306.t1' in scope SELECT id FROM test_fiykc306.t1: While processing conversation IN (SELECT id FROM test_fiykc306.t1). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1464: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6aafd5 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d69f716 14. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d68f20d 15. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d652bb2 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d66ae9f 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d66b58e 18. ./build_docker/./src/Storages/ConstraintsDescription.cpp:146: DB::ConstraintsDescription::getExpressions(std::shared_ptr, DB::NamesAndTypesList const&) const @ 0x0000000030303066 19. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:34: DB::CheckConstraintsTransform::CheckConstraintsTransform(DB::StorageID const&, DB::Block const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x0000000031da91a7 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::StorageID&&, DB::Block const&, DB::ConstraintsDescription&, std::shared_ptr&) @ 0x000000002dcf7c92 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::Block const&, DB::ConstraintsDescription&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::Block const&, DB::ConstraintsDescription&, std::shared_ptr&) @ 0x000000002dcf7aae 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::InterpreterInsertQuery::buildPreSinkChain(DB::Block const&, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002dce97e9 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:511: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceaf0f 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:32:00.549131 [ 34259 ] {e9094e69-1005-4483-be24-a4e001a19eac} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54576) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.549884 [ 3815 ] {e0788d6b-c5f6-4218-9169-2a1da0852f65} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54574) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.566252 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.566746 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.629097 [ 5105 ] {4475871c-98cb-4af0-b649-f5918242bbe5} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54592) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.682489 [ 5105 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.752750 [ 3816 ] {6cd82049-cf58-4ab9-9e83-52049e8e92b8} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54602) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.777268 [ 3816 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.808829 [ 34277 ] {459a0b57-325c-4913-8fb2-3d79465b1469} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 467, line 156) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.821374 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.835055 [ 3815 ] {b985af31-13c0-4456-af7d-c0084b5f3667} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54616) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.835248 [ 32979 ] {1d4dcf22-1d9b-4812-b253-f9922d526b2a} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54610) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.835601 [ 34273 ] {7bcfa154-7aae-4b22-a3d2-35003e15a1ad} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54634) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.836081 [ 46282 ] {fd94c4d2-bc53-465a-b841-4d2c9e001535} executeQuery: Code: 57. DB::Exception: Table test_fiykc306.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02841_not_ready_set_constraints.sql) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_fiykc306.t2 UUID '8fa12dc9-8fab-414f-9e63-e2911a03acb6' (`conversation` UInt64, CONSTRAINT constraint_conversation CHECK conversation IN (SELECT id FROM test_fiykc306.t1)) ENGINE = MergeTree ORDER BY conversation SETTINGS index_granularity = 61484, 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 = 0, compact_parts_max_bytes_to_buffer = 94534557, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 9789585, merge_max_block_size = 13995, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 2566185064, 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 = 7828664, 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 = 47210, primary_key_compress_block_size = 70389, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.848135 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.852216 [ 34273 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.852705 [ 32979 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.878425 [ 34259 ] {4a6c9e1d-3ce9-4ddc-9c7e-c5cdec7ed614} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54630) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.892619 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.959324 [ 46282 ] {fd94c4d2-bc53-465a-b841-4d2c9e001535} executeQuery: Code: 57. DB::Exception: Table test_fiykc306.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34944) (comment: 02841_not_ready_set_constraints.sql) (query 11, line 27) (in query: CREATE TABLE t2 (`conversation` UInt64, CONSTRAINT constraint_conversation CHECK conversation IN (SELECT id FROM t1)) ENGINE = MergeTree ORDER BY conversation SETTINGS index_granularity = 61484, 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 = 0, compact_parts_max_bytes_to_buffer = 94534557, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 9789585, merge_max_block_size = 13995, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 2566185064, 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 = 7828664, 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 = 47210, primary_key_compress_block_size = 70389, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.966519 [ 5105 ] {fce2f877-41c9-4c80-a659-8fb2195e43fd} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54646) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.966692 [ 46282 ] {} TCPHandler: Code: 57. DB::Exception: Table test_fiykc306.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.977856 [ 3815 ] {5f9440e6-987c-4b8c-973e-f36950d202e4} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54658) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.987598 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:00.998429 [ 3815 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.150538 [ 34259 ] {7ebb20ba-b42f-4237-80f6-02d95871753c} executeQuery: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54662) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.152190 [ 3816 ] {306b59de-f7d6-4b84-bffa-620691321723} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54660) (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_5/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 = 53925, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 372541772, compact_parts_max_granules_to_buffer = 120, compact_parts_merge_max_bytes_to_prefetch_part = 31224101, merge_max_block_size = 5696, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 561728, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 737180041, index_granularity_bytes = 6701734, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 43594, primary_key_compress_block_size = 14723, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.176517 [ 3766 ] {c3455ee4-d62e-4779-9d31-0f2ea4fe11f8} executeQuery: Code: 57. DB::Exception: Table test_aauvdr7w.null_before already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54470) (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 = 11208, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 90, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 497110329, compact_parts_max_granules_to_buffer = 133, compact_parts_merge_max_bytes_to_prefetch_part = 13529756, merge_max_block_size = 14571, old_parts_lifetime = 223., prefer_fetch_merged_part_size_threshold = 5512082603, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 86, min_merge_bytes_to_use_direct_io = 3956536962, index_granularity_bytes = 17652596, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 17739, primary_key_compress_block_size = 93610, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.187779 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.190774 [ 34259 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:54662, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:01.190847 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c77ec24 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c781e07 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c782f9d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.196965 [ 34259 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:54662, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:01.197673 [ 3816 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:54660, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:01.199645 [ 3816 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:54660, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:01.225848 [ 34277 ] {4a2db18c-6949-41fe-a510-72e9035ebb10} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 470, line 157) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.231968 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.275595 [ 3766 ] {} TCPHandler: Code: 57. DB::Exception: Table test_aauvdr7w.null_before already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.446205 [ 34277 ] {1e78afd1-ceec-4301-af04-bb07af51f93c} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 473, line 158) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.454902 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.784065 [ 34277 ] {5fa2c88f-c965-4cf3-8de6-61151d0c2347} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 476, line 159) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:01.787432 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:02.266965 [ 3452 ] {4fe5fdcb-6782-4e79-926b-01e33cca0749::all_1_5_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c5a377 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3bbbe1 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c260b8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:03.183341 [ 5105 ] {b2fd8c7d-4cfd-4c1d-9227-4c5e8058be0c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54780) (comment: 02346_fulltext_index_search.sql) (query 6, line 13) (in query: CREATE TABLE tab (`k` UInt64, `s` String, INDEX af s TYPE full_text(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 2, index_granularity_bytes = '10Mi', 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 = 205073018, compact_parts_max_bytes_to_buffer = 339045468, compact_parts_max_granules_to_buffer = 243, compact_parts_merge_max_bytes_to_prefetch_part = 17748593, merge_max_block_size = 19511, old_parts_lifetime = 448., prefer_fetch_merged_part_size_threshold = 7505685027, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 99, min_merge_bytes_to_use_direct_io = 173310922, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 64, 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 = 57384, primary_key_compress_block_size = 77853, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:03.189790 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:03.694634 [ 3766 ] {59bef67a-cc78-48ac-8dbd-a19d60cc3e5f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54794) (comment: 00976_ttl_with_old_parts.sql) (query 2, line 3) (in query: CREATE TABLE ttl (`d` Date, `a` Int) ENGINE = MergeTree PARTITION BY toDayOfMonth(d) ORDER BY a SETTINGS remove_empty_parts = 0, index_granularity = 55702, min_bytes_for_wide_part = 536705056, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 63, min_bytes_for_full_part_storage = 481218756, compact_parts_max_bytes_to_buffer = 329117499, compact_parts_max_granules_to_buffer = 172, compact_parts_merge_max_bytes_to_prefetch_part = 26747389, merge_max_block_size = 8627, 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 = 10513593723, index_granularity_bytes = 7701506, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 83440, primary_key_compress_block_size = 47452, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:03.721136 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:04.259327 [ 34277 ] {0d9500b7-c878-461e-9956-276155a794c4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 485, line 162) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:04.284167 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:04.749785 [ 3766 ] {d12e9a64-240f-475d-a606-d741cbff49da} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54824) (comment: 02962_indexHint_rpn_construction.sql) (query 1, line 1) (in query: CREATE TABLE tab (`foo` Array(LowCardinality(String)), INDEX idx foo TYPE bloom_filter GRANULARITY 1) ENGINE = MergeTree PRIMARY KEY tuple() SETTINGS index_granularity = 16884, min_bytes_for_wide_part = 81484422, 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 = 368547130, compact_parts_max_bytes_to_buffer = 478143105, compact_parts_max_granules_to_buffer = 133, compact_parts_merge_max_bytes_to_prefetch_part = 4658818, merge_max_block_size = 15294, 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 = 49, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4602748, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 87, 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 = 24552, primary_key_compress_block_size = 54742, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:04.763464 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:05.423987 [ 34259 ] {43b126fc-d761-4f4a-81fb-7e8a8ead9c48} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54856) (comment: 02791_final_block_structure_mismatch_bug.sql) (query 2, line 3) (in query: CREATE TABLE test_block_mismatch (`a` UInt32, `b` DateTime) ENGINE = ReplacingMergeTree PARTITION BY toYYYYMM(b) ORDER BY (toDate(b), a) SETTINGS index_granularity = 12858, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 148029026, compact_parts_max_granules_to_buffer = 192, compact_parts_merge_max_bytes_to_prefetch_part = 19665916, merge_max_block_size = 14100, 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 = 1, index_granularity_bytes = 26988274, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 52561, primary_key_compress_block_size = 14033, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:05.435344 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:05.443628 [ 6126 ] {c19fa493-680f-41b7-ad9c-fdc113ff12e7} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 9.66 MiB (attempt to allocate chunk of 2.68 MiB bytes), maximum: 9.54 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54298) (comment: 03214_count_distinct_null_key_memory_leak.sql) (query 4, line 16) (in query: SELECT count(distinct b) FROM testnull GROUP BY a SETTINGS max_memory_usage = 10000000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399291f 9. ./src/Common/Allocator.h:112: HashTable, HashTableCell, UInt128TrivialHash, HashTableNoState>, UInt128TrivialHash, HashTableGrower<3ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x0000000026e21148 10. ./src/Common/HashTable/HashTable.h:926: DB::AggregateFunctionUniq>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000026f2d914 11. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:371: DB::AggregateFunctionNullUnary::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000284410af 12. ./src/AggregateFunctions/IAggregateFunction.h:448: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000284430e7 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002d6c30e2 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1264: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002d6c278b 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch>>, true>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>>(DB::AggregationMethodStringNoCache>>, true>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d9371ae 16. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl>>, true>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>>(DB::AggregationMethodStringNoCache>>, true>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d935028 17. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl>>, true>>(DB::AggregationMethodStringNoCache>>, true>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d753d11 18. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6c0389 19. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7b52 20. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:32:05.553771 [ 6126 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 9.66 MiB (attempt to allocate chunk of 2.68 MiB bytes), maximum: 9.54 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399291f 9. ./src/Common/Allocator.h:112: HashTable, HashTableCell, UInt128TrivialHash, HashTableNoState>, UInt128TrivialHash, HashTableGrower<3ul>, AllocatorWithStackMemory, 128ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x0000000026e21148 10. ./src/Common/HashTable/HashTable.h:926: DB::AggregateFunctionUniq>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000026f2d914 11. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:371: DB::AggregateFunctionNullUnary::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000284410af 12. ./src/AggregateFunctions/IAggregateFunction.h:448: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000284430e7 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002d6c30e2 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1264: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002d6c278b 15. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch>>, true>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>>(DB::AggregationMethodStringNoCache>>, true>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d9371ae 16. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl>>, true>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>>(DB::AggregationMethodStringNoCache>>, true>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, true>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d935028 17. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl>>, true>>(DB::AggregationMethodStringNoCache>>, true>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d753d11 18. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6c0389 19. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7b52 20. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:06.538908 [ 34259 ] {2a00db3e-b332-4a9a-8950-fe03c28b983c} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017cd735b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:32:06.546072 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017cd735b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.021256 [ 34259 ] {0950e7d7-1fb3-4d80-900c-bb66879622db} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017cd71fe 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.087210 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017cd71fe 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.229551 [ 34277 ] {b3e5941b-93bd-45b9-8e10-b864656f757a} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 500, line 167) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.234180 [ 34259 ] {b9f6dc2d-77f8-4485-b682-c40adac0b3d8} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017cd71fe 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.240168 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.244803 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdcf6f 5. DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017cd71fe 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.424969 [ 34259 ] {0f574de3-049e-45f9-bf2a-556af091ca0e} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function generateRandomStructure must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc96eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.452508 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc96eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.481793 [ 34259 ] {0eb83f00-c0d1-4bf8-87a9-4d07f06021e3} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function generateRandomStructure must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc96eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:32:07.485420 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc96eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:32:08.081182 [ 34259 ] {b9931dc3-a69a-4792-9dc3-3fd6a96f1071} 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.3.20372.altinityantalya (altinity build)) (from [::1]:54906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000284e3cb8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:32:08.111982 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000284e3cb8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:32:09.308441 [ 46282 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:09.929120 [ 3766 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'group_by_use_nulls' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028494136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb870f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 7. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 8. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 9. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 10. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 11. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:09.931976 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:32:10.038470 [ 5382 ] {61454808-116b-4e7b-a1d9-76be82bc4d79} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39710) (comment: 02707_skip_index_with_in.sql) (query 5, line 18) (in query: EXPLAIN SELECT count() FROM t_skip_index_in WHERE c IN (SELECT throwIf(1)) SETTINGS use_skip_indexes = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 20. ./build_docker/./src/Interpreters/PreparedSets.cpp:270: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x000000002dee1c2c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:390: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x0000000030eba88f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:352: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x0000000030eba57c 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030eccdb2 24. ./src/Storages/MergeTree/RPNBuilder.h:205: DB::MergeTreeIndexConditionBloomFilter::MergeTreeIndexConditionBloomFilter(DB::ActionsDAG const*, std::shared_ptr, DB::Block const&, unsigned long) @ 0x0000000030eb88b1 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, unsigned long const&, std::allocator, 0>(std::allocator, DB::ActionsDAG const*&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000030ece737 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ActionsDAG const*&, std::shared_ptr&, DB::Block const&, unsigned long const&, 0>(std::allocator const&, DB::ActionsDAG const*&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000030ece54e 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x0000000030ec25ee 28. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1660: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000321b1cd9 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1697: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x00000000321b043e 30. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228d4bc 31. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003228c797 2025.07.13 02:32:10.045460 [ 5382 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 20. ./build_docker/./src/Interpreters/PreparedSets.cpp:270: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x000000002dee1c2c 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:390: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x0000000030eba88f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:352: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x0000000030eba57c 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030eccdb2 24. ./src/Storages/MergeTree/RPNBuilder.h:205: DB::MergeTreeIndexConditionBloomFilter::MergeTreeIndexConditionBloomFilter(DB::ActionsDAG const*, std::shared_ptr, DB::Block const&, unsigned long) @ 0x0000000030eb88b1 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, unsigned long const&, std::allocator, 0>(std::allocator, DB::ActionsDAG const*&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000030ece737 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ActionsDAG const*&, std::shared_ptr&, DB::Block const&, unsigned long const&, 0>(std::allocator const&, DB::ActionsDAG const*&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000030ece54e 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x0000000030ec25ee 28. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1660: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000321b1cd9 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1697: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x00000000321b043e 30. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228d4bc 31. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003228c797 2025.07.13 02:32:10.220063 [ 3766 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'group_by_use_nulls' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028494136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb870f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 7. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 8. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 9. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 10. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 11. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:10.222100 [ 3766 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:32:10.856140 [ 34259 ] {9f958e65-6c8a-4782-8558-4cce6995b633} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40082) (comment: 00909_kill_not_initialized_query.sh) (query 1, line 1) (in query: CREATE TABLE cannot_kill_query (`x` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 63836, 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 = 0, compact_parts_max_bytes_to_buffer = 449668023, compact_parts_max_granules_to_buffer = 192, compact_parts_merge_max_bytes_to_prefetch_part = 978110, merge_max_block_size = 13919, old_parts_lifetime = 326., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 21160730, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 73649, primary_key_compress_block_size = 35056, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:10.872881 [ 34259 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:10.900253 [ 57039 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028494136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb870f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 7. ./build_docker/./src/Interpreters/Context.cpp:2687: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d4886cc 8. ./build_docker/./src/Interpreters/Context.cpp:1854: DB::Context::setCurrentProfilesWithLock(DB::SettingsProfilesInfo const&, bool, std::lock_guard const&) @ 0x000000002d485a2a 9. ./build_docker/./src/Interpreters/Context.cpp:1848: DB::Context::setCurrentProfileWithLock(StrongTypedef, DB::UUIDTag> const&, bool, std::lock_guard const&) @ 0x000000002d48857b 10. ./build_docker/./src/Interpreters/Context.cpp:1836: DB::Context::setCurrentProfileWithLock(String const&, bool, std::lock_guard const&) @ 0x000000002d4883d5 11. ./build_docker/./src/Interpreters/Context.cpp:2611: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x000000002d4930db 12. ./build_docker/./src/Interpreters/Context.cpp:2626: DB::Context::applySettingsChangesWithLock(DB::SettingsChanges const&, std::lock_guard const&) @ 0x000000002d488919 13. ./build_docker/./src/Interpreters/Context.cpp:2668: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x000000002d4938b0 14. ./build_docker/./src/Server/HTTPHandler.cpp:458: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf2c0 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:11.441011 [ 6024 ] {fb5aecee-b950-45fc-a457-1753613d581f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40186) (comment: 02461_alter_update_respect_part_column_type_bug.sql) (query 1, line 1) (in query: drop table if exists src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:32:11.470331 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:32:13.059904 [ 3455 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b74b8fb6-05a5-4d81-8ac8-db6cbf43b2a7::202507_98_123_5}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:14.145713 [ 34273 ] {cbbdb23a-a81a-4567-97a9-c4af72fda25d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54898) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:14.172151 [ 34273 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:14.476727 [ 57041 ] {e4006c43-ffca-4eb9-b736-8a9c1aab2a5d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57938) (comment: 02099_hashed_array_dictionary_complex_key.gen.sql) (in query: DROP DATABASE IF EXISTS test_adhu7tze SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:32:14.482514 [ 57041 ] {e4006c43-ffca-4eb9-b736-8a9c1aab2a5d} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:14.839614 [ 6126 ] {3d6aeeca-56c1-483b-bd6c-92db3db5eabc} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40906) (comment: 02695_logical_optimizer_alias_bug.sql) (query 1, line 1) (in query: CREATE TABLE test_local (`id` UInt32, `path` LowCardinality(String)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 50527, min_bytes_for_wide_part = 1021036628, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 361912975, compact_parts_max_granules_to_buffer = 212, compact_parts_merge_max_bytes_to_prefetch_part = 14523490, merge_max_block_size = 21466, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 134616543, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4661490079, index_granularity_bytes = 28206029, 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 = true, marks_compress_block_size = 92368, primary_key_compress_block_size = 67836, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:14.845934 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:15.966429 [ 6126 ] {2a65b371-0ccb-4198-8b30-a0d6570d8d55} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40988) (comment: 03280_json_subcolumns_in_primary_key_select_final.gen.sql) (query 7, line 10) (in query: CREATE TABLE test (`value` UInt64, `json` JSON(a UInt32, b String), `data` String) ENGINE = SummingMergeTree(value) ORDER BY (json.a, json.b) SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 1, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 61, min_bytes_for_full_part_storage = 491184822, compact_parts_max_bytes_to_buffer = 53323975, compact_parts_max_granules_to_buffer = 46, compact_parts_merge_max_bytes_to_prefetch_part = 1137427, merge_max_block_size = 14060, 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 = 20, min_merge_bytes_to_use_direct_io = 1643924483, index_granularity_bytes = 22906527, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 86, 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 = 76059, primary_key_compress_block_size = 38693, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:15.976204 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:16.476952 [ 34340 ] {74f3da43-0169-4330-85dc-9e7bafe8acf0} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41216) (comment: 00752_low_cardinality_mv_1.sql) (query 3, line 4) (in query: CREATE TABLE lc_00752 (`str` LowCardinality(String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 9990, min_bytes_for_wide_part = 998635890, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 35, min_bytes_for_full_part_storage = 391532294, compact_parts_max_bytes_to_buffer = 200205498, compact_parts_max_granules_to_buffer = 129, compact_parts_merge_max_bytes_to_prefetch_part = 13751662, merge_max_block_size = 20730, old_parts_lifetime = 308., 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 = 10737418240, index_granularity_bytes = 14145269, 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 = 48118, primary_key_compress_block_size = 98369, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:16.490619 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7c6181 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf1a8 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:20.388092 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:20.389295 [ 34260 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:32:20.468333 [ 2824 ] {81dd29e5-5961-47f8-8618-8b9e76c5715e} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading test: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (S3_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51908) (comment: 03215_parsing_archive_name_s3.sql) (query 4, line 9) (in query: SELECT _file, _path FROM s3(s3_conn, filename='test :: 03215_archive.csv') ORDER BY (_file, _path);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002b842b7a 5. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x000000002b841f9b 6. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:364: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002b836a4e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:924: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002b5b021d 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:1091: DB::StorageObjectStorageSource::ArchiveIterator::next(unsigned long) @ 0x000000002b5b2475 9. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:189: DB::ReadBufferIterator::next() @ 0x000000002b51821b 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c505c 11. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 12. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:537: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x000000002b50b29f 13. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:64: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, std::shared_ptr, std::shared_ptr, std::optional, String&, std::shared_ptr const&) @ 0x000000002b60e95a 14. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:137: 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, bool, std::optional) @ 0x000000002b50395b 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 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&&, bool&&) @ 0x0000000028577f9a 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, 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&&, bool&&) @ 0x0000000028577ae7 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 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&&, bool&&) @ 0x00000000285778db 18. ./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 @ 0x000000002854681d 19. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c1d49 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 21. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:32:20.487027 [ 2824 ] {} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading test: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002b842b7a 5. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x000000002b841f9b 6. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:364: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002b836a4e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:924: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002b5b021d 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:1091: DB::StorageObjectStorageSource::ArchiveIterator::next(unsigned long) @ 0x000000002b5b2475 9. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:189: DB::ReadBufferIterator::next() @ 0x000000002b51821b 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c505c 11. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317cadf0 12. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:537: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x000000002b50b29f 13. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:64: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, std::shared_ptr, std::shared_ptr, std::optional, String&, std::shared_ptr const&) @ 0x000000002b60e95a 14. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:137: 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, bool, std::optional) @ 0x000000002b50395b 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 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&&, bool&&) @ 0x0000000028577f9a 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, 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&&, bool&&) @ 0x0000000028577ae7 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 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&&, bool&&) @ 0x00000000285778db 18. ./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 @ 0x000000002854681d 19. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c1d49 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 21. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 2025.07.13 02:32:20.656755 [ 57041 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:20.735845 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:20.740897 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:32:21.114497 [ 5826 ] {0d2f92c2-26c9-48e5-9431-6b757070f748} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52360) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:32:21.118546 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:32:21.469923 [ 6022 ] {89199516-2b3e-4520-8b78-306eff43aa98} 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.3.20372.altinityantalya (altinity build)) (from [::1]:52448) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:32:21.484959 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:32:22.728911 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:22.729701 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:32:23.797073 [ 3461 ] {4e36ba87-7288-444b-88e6-2db2be2415c0::-1_64_64_0_538} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/4e3/4e36ba87-7288-444b-88e6-2db2be2415c0/-1_64_64_0_405/data.cmrk3 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading from part /var/lib/clickhouse/store/4e3/4e36ba87-7288-444b-88e6-2db2be2415c0/-1_64_64_0_405/ in table test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0) located on disk default of type local, from mark 0 with max_rows_to_read = 27): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:24.171224 [ 3461 ] {4e36ba87-7288-444b-88e6-2db2be2415c0::-1_64_64_0_538} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/4e3/4e36ba87-7288-444b-88e6-2db2be2415c0/-1_64_64_0_405/data.cmrk3 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading from part /var/lib/clickhouse/store/4e3/4e36ba87-7288-444b-88e6-2db2be2415c0/-1_64_64_0_405/ in table test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0) located on disk default of type local, from mark 0 with max_rows_to_read = 27): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000030f05374 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:232: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000030f03b9a 18. ./build_docker/./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()() @ 0x0000000030f0807b 19. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task ()>::operator()() @ 0x0000000030f0bd12 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 8. ./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&&) @ 0x0000000030dd2141 9. ./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 @ 0x0000000030dcc68b 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:24.182718 [ 3461 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4e36ba87-7288-444b-88e6-2db2be2415c0::-1_64_64_0_538}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/4e3/4e36ba87-7288-444b-88e6-2db2be2415c0/-1_64_64_0_405/data.cmrk3 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading from part /var/lib/clickhouse/store/4e3/4e36ba87-7288-444b-88e6-2db2be2415c0/-1_64_64_0_405/ in table test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0) located on disk default of type local, from mark 0 with max_rows_to_read = 27): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000030f05374 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:232: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000030f03b9a 18. ./build_docker/./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()() @ 0x0000000030f0807b 19. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task ()>::operator()() @ 0x0000000030f0bd12 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 8. ./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&&) @ 0x0000000030dd2141 9. ./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 @ 0x0000000030dcc68b 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:24.642476 [ 57041 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:24.943484 [ 57041 ] {5d6f70df-6e94-4aaf-8eb6-a9f994ea0eeb} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0121109): 0.0121109. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36442) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0121109), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:32:24.946403 [ 57041 ] {5d6f70df-6e94-4aaf-8eb6-a9f994ea0eeb} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0121109): 0.0121109. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:24.967797 [ 57039 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_57696: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.027206 [ 57039 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_57696: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.152987 [ 34273 ] {f50acf83-88e4-4135-bd31-1c018c4ff8dd} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0121124): 0.0121124. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36462) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0121124), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:32:25.155509 [ 34273 ] {f50acf83-88e4-4135-bd31-1c018c4ff8dd} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0121124): 0.0121124. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.223946 [ 34273 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_57696: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.369983 [ 57039 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_57696: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.401796 [ 34273 ] {031b1b85-21d1-48a3-9a94-a089250abb3f} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0130160): 0.0130160. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36502) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0130160), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:32:25.409129 [ 34273 ] {031b1b85-21d1-48a3-9a94-a089250abb3f} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0130160): 0.0130160. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.423343 [ 29256 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_57696: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.543526 [ 29256 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_1: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.544354 [ 29256 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_1: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.631464 [ 57039 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_57696: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x0000000031708ed4 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315bb0c4 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bb7f1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.704629 [ 6126 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_2: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:25.705631 [ 6126 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_2: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:26.382836 [ 3815 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_1: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:26.383423 [ 3815 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_1: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:26.411874 [ 4663 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_57696 failed. 2025.07.13 02:32:26.413088 [ 34259 ] {1dc93a1f-9a83-437e-956a-d182e72ddf5f} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696): mysqlxx::ConnectionFailed 2025.07.13 02:32:26.413844 [ 4663 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.13 02:32:26.414093 [ 34259 ] {1dc93a1f-9a83-437e-956a-d182e72ddf5f} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.13 02:32:26.414657 [ 34259 ] {1dc93a1f-9a83-437e-956a-d182e72ddf5f} Application: Connection to mysql failed 1 times 2025.07.13 02:32:26.461337 [ 34259 ] {1dc93a1f-9a83-437e-956a-d182e72ddf5f} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53346) (comment: 02833_concurrent_sessions.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_57696', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x000000003595d4bf 6. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002c9373f8 7. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000030566cd6 8. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000305665b8 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::MySQLSettings, std::allocator, 0>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000285238f9 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000028523674 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000028522710 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:32:26.465874 [ 34340 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_2: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:26.466437 [ 34340 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_2: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:26.486247 [ 34259 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x000000003595d4bf 6. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002c9373f8 7. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000030566cd6 8. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000305665b8 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::MySQLSettings, std::allocator, 0>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000285238f9 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000028523674 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000028522710 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:32:27.074213 [ 34340 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_1: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:27.075632 [ 34340 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_1: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:27.139698 [ 46282 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_2: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:27.140484 [ 46282 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_57696_2: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:27.816092 [ 4663 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_57696 failed. 2025.07.13 02:32:27.826352 [ 4663 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.13 02:32:27.828354 [ 46282 ] {6a6609d3-0e0a-4721-bf0e-ceb5f7836847} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696): mysqlxx::ConnectionFailed 2025.07.13 02:32:27.832362 [ 46282 ] {6a6609d3-0e0a-4721-bf0e-ceb5f7836847} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.13 02:32:27.834539 [ 46282 ] {6a6609d3-0e0a-4721-bf0e-ceb5f7836847} Application: Connection to mysql failed 1 times 2025.07.13 02:32:27.843274 [ 46282 ] {6a6609d3-0e0a-4721-bf0e-ceb5f7836847} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53632) (comment: 02833_concurrent_sessions.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_57696', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x000000003595d4bf 6. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002c9373f8 7. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000030566cd6 8. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000305665b8 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::MySQLSettings, std::allocator, 0>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000285238f9 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000028523674 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000028522710 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:32:27.943636 [ 46282 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x000000003595d4bf 6. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002c9373f8 7. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000030566cd6 8. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000305665b8 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::MySQLSettings, std::allocator, 0>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000285238f9 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000028523674 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000028522710 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:32:29.241430 [ 4663 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_57696 failed. 2025.07.13 02:32:29.244374 [ 57041 ] {9957dc1e-2a22-4c03-abde-f61de408d8ff} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696): mysqlxx::ConnectionFailed 2025.07.13 02:32:29.244517 [ 4663 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.13 02:32:29.245298 [ 57041 ] {9957dc1e-2a22-4c03-abde-f61de408d8ff} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.13 02:32:29.246113 [ 57041 ] {9957dc1e-2a22-4c03-abde-f61de408d8ff} Application: Connection to mysql failed 1 times 2025.07.13 02:32:29.249819 [ 57041 ] {9957dc1e-2a22-4c03-abde-f61de408d8ff} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33432) (comment: 02833_concurrent_sessions.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_57696', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x000000003595d4bf 6. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002c9373f8 7. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000030566cd6 8. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000305665b8 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::MySQLSettings, std::allocator, 0>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000285238f9 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000028523674 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000028522710 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:32:29.268346 [ 57041 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_57696, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_57696: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x000000003595d4bf 6. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002c9373f8 7. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000030566cd6 8. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000305665b8 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::MySQLSettings, std::allocator, 0>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000285238f9 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000028523674 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000028522710 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:32:31.586588 [ 34277 ] {2392c238-6f6f-443e-a569-b36572c5d8d4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 509, line 170) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:31.607793 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:34.219343 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:34.746787 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:36.836594 [ 5732 ] {b724bc9a-3cd9-4a52-9c03-32f3d7354150} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:55430). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55430) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316c2df8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2679 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.846012 [ 5732 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:55430). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316c2df8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2679 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.849653 [ 34259 ] {3237a9f8-f33d-4ead-8de1-af22188d6e2e} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33466). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:36.859352 [ 34259 ] {3237a9f8-f33d-4ead-8de1-af22188d6e2e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33466). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33466) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: ALTER TABLE alter_table DELETE WHERE rand() % 2 = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.864128 [ 34259 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33466). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.875098 [ 7056 ] {e6eb4642-4f5b-4ddb-899c-37e8d3e23f72} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:55432). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55432) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316c2df8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2679 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.881158 [ 7056 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:55432). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316c2df8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2679 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.940374 [ 5379 ] {989fb683-74cb-42d3-b8c8-aac4acbffd49} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:55446). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55446) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316c2df8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2679 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.951517 [ 5379 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:55446). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316c2df8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2679 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:36.974311 [ 46294 ] {f2f5d7d5-b98c-45ab-8e3a-1a0ca63eba09} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34648) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.061101 [ 46294 ] {f2f5d7d5-b98c-45ab-8e3a-1a0ca63eba09} 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]:34648). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:37.068963 [ 46294 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.375647 [ 2824 ] {f27e0c91-4e49-4bec-9bcc-88bfcdc839eb} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34702, local: [::1]:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34702) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.501037 [ 2824 ] {f27e0c91-4e49-4bec-9bcc-88bfcdc839eb} 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]:34702). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316adca3 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:37.511140 [ 2824 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34702, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.533508 [ 29256 ] {faf386e8-c880-4f79-8d64-4207088622cd} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34172) (comment: 00181_aggregate_functions_statistics_stable.sql) (query 20, line 67) (in query: SELECT round(abs(COVAR1 - COVAR2), 6) FROM ( SELECT arrayJoin([1]) AS ID2, covarSampStable(x_value, y_value) AS COVAR1 FROM series ) ANY INNER JOIN ( SELECT arrayJoin([1]) AS ID2, sum(VAL) / (count() - 1) AS COVAR2 FROM ( SELECT (X - AVG_X) * (Y - AVG_Y) AS VAL FROM ( SELECT toUInt32(arrayJoin([1, 2, 3, 4, 5, 6, 7, 8, 9, 10])) AS ID, avg(x_value) AS AVG_X, avg(y_value) AS AVG_Y FROM series ) ANY INNER JOIN ( SELECT i AS ID, x_value AS X, y_value AS Y FROM series ) USING ID ) ) USING ID2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031df546f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031de6174 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031de68c1 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031df4614 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0e7a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0c8e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c3a4a09 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321327e9 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.543148 [ 29256 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031df546f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031de6174 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031de68c1 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031df4614 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0e7a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3b0c8e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c3a4a09 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321327e9 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.663857 [ 57041 ] {e5c7bec6-5b8e-49a1-ae07-8a17c8130cb0} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33740). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:37.672396 [ 6024 ] {465fd97c-9d1e-4ac1-b57b-5254e05a44e9} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34802) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.682415 [ 6024 ] {465fd97c-9d1e-4ac1-b57b-5254e05a44e9} 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]:34802). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:37.693402 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.756227 [ 57041 ] {e5c7bec6-5b8e-49a1-ae07-8a17c8130cb0} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33740). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33740) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: ALTER TABLE alter_table DELETE WHERE rand() % 2 = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.758647 [ 57041 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33740). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.759099 [ 6022 ] {79933610-74f0-41bc-b64c-66b976a9c297} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34736, local: [::1]:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34736) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:37.763243 [ 6022 ] {79933610-74f0-41bc-b64c-66b976a9c297} 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]:34736). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316adca3 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:37.765702 [ 6022 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34736, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:38.272400 [ 6022 ] {92efd4e0-18d0-4a4e-ba1b-f3ab7cc34d27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34956) (comment: 03217_fliter_pushdown_no_keys.sql) (query 2, line 5) (in query: select * from ( select sum(last_seen) as dates_seen, materialize(2) as last_seen ) where last_seen < 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:38.283843 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:39.232961 [ 6024 ] {ea999310-0cfd-470e-baae-2fc9429f706d} executeQuery: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34994) (comment: 02958_transform_enum.sql) (query 2, line 2) (in query: WITH arrayJoin(['Hello', 'world'])::Enum('Hello', 'world') AS x SELECT x, transform(x, ['Hello', 'world', 'goodbye'], [123, 456], 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4d1f01 6. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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 @ 0x000000002afc524c 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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) @ 0x000000002afc4c86 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25ddae 14. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25d481 15. DB::(anonymous namespace)::FunctionTransform::initialize(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020c7340f 16. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038eff69b 17. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020c22aad 18. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 25. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 26. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 28. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 29. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 30. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 2025.07.13 02:32:39.297477 [ 6024 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4d1f01 6. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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 @ 0x000000002afc524c 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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) @ 0x000000002afc4c86 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25ddae 14. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25d481 15. DB::(anonymous namespace)::FunctionTransform::initialize(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020c7340f 16. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038eff69b 17. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020c22aad 18. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 25. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 26. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 28. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 29. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 30. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 2025.07.13 02:32:40.169573 [ 34340 ] {3ef7e27d-6f76-48ad-bcf0-f44cfe3116a1} test_7.table_one (1d9ed9fe-02c5-48e4-8744-13f7b5a1ddcf): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:32:40.192548 [ 3816 ] {8b9f8bdf-cc3a-4e00-b924-c3c18fa1b957} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34052). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:40.270032 [ 3816 ] {8b9f8bdf-cc3a-4e00-b924-c3c18fa1b957} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34052). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34052) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: ALTER TABLE alter_table DELETE WHERE rand() % 2 = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:40.272385 [ 3816 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34052). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:42.630715 [ 34260 ] {924d4a32-856b-4066-bd71-14f84971ad5a} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34504). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:42.634081 [ 34260 ] {924d4a32-856b-4066-bd71-14f84971ad5a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34504). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34504) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: ALTER TABLE alter_table DELETE WHERE rand() % 2 = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:42.634835 [ 34340 ] {f6692598-1942-4053-a80b-395faf3061ff} test_7.table_one (510582ee-81cf-4741-9268-d7384eb3dd45): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:32:42.645012 [ 34260 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34504). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:32:42.673745 [ 3462 ] {4e36ba87-7288-444b-88e6-2db2be2415c0::4_715_775_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:43.047849 [ 2827 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5612 similar messages) 2025.07.13 02:32:43.451389 [ 3453 ] {4e36ba87-7288-444b-88e6-2db2be2415c0::8_714_772_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:43.526514 [ 34340 ] {f1016d1b-8139-4f3b-a962-a18a856b12d2} test_7.table_two (4a76aa82-fcd0-4c72-88d0-0f6d522503cf): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:32:46.822240 [ 5380 ] {de784356-2a91-45af-8611-7c566688d4d2} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33708). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33708) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:46.855699 [ 5380 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:47.927395 [ 34340 ] {72addc1b-cd3a-4743-be15-1a3c45844b78} test_7.table_two (4ca412a9-e2eb-49ee-8019-b646c94a69a5): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:32:48.112812 [ 5826 ] {45f77310-82c5-400b-af01-fd0e2fd8d096} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33856). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33856) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:48.132243 [ 5826 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33856). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:48.183725 [ 57044 ] {d074028a-43ad-482d-94aa-62eefd2118fc} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33820). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33820) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:48.202357 [ 5382 ] {601f79a6-c130-4679-9133-04d58ce592ee} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33846). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33846) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:48.217760 [ 5382 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33846). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:48.252951 [ 57044 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33820). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:32:50.454176 [ 7150 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:32:56: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:52.186831 [ 29256 ] {8168fc9c-6a5e-40ed-8eb8-07ea1b26277b} executeQuery: std::exception. Code: 1001, type: Azure::Core::Http::TransportException, e.what() = Fail to get a new connection for: http://localhost:10000. Could not connect to server (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58624) (comment: 03008_azure_plain_rewritable_with_empty_col.sh) (query 1, line 2) (in query: CREATE TABLE test_azure_mt (`a` Int32, `b` Int64, `empty` String) ENGINE = MergeTree ORDER BY (a, b) SETTINGS min_bytes_for_wide_part = 0, disk = disk(type = object_storage, metadata_type = plain_rewritable, object_storage_type = azure_blob_storage, name = 'cont-03008-azure-plain-rewritable-with-empty-col-test-z7erpvqi', path = '/var/lib/clickhouse/disks/cont-03008-azure-plain-rewritable-with-empty-col-test-z7erpvqi/tables', container_name = 'cont-03008-azure-plain-rewritable-with-empty-col-test-z7erpvqi', endpoint = 'http://localhost:10000/devstoreaccount1/cont-03008-azure-plain-rewritable-with-empty-col-test-z7erpvqi/tables', account_name = 'devstoreaccount1', account_key = 'Eby8vdM02xNOcqFlqUwJPLlmEtlCDXJ1OUzFT50uSRZ6IFsuFq2UVErCz4I6tq/K1SZFPTOtr/KBHBeksoGMGw=='), index_granularity = 32989, ratio_of_defaults_for_sparse_serialization = 0.4694712460041046, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 405083717, compact_parts_max_bytes_to_buffer = 183687407, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 32820662, merge_max_block_size = 17436, old_parts_lifetime = 23., 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 = 10737418240, index_granularity_bytes = 4157463, 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 = true, marks_compress_block_size = 81477, primary_key_compress_block_size = 14421, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:32: std::runtime_error::runtime_error(String const&) @ 0x0000000038fb32de 2. ./build_docker/./contrib/azure/sdk/core/azure-core/src/exception.cpp:20: Azure::Core::RequestFailedException::RequestFailedException(String const&) @ 0x00000000362058ae 3. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/http.hpp:66: Azure::Core::Http::CurlConnection::CurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, String const&, String const&) @ 0x0000000036201215 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: Azure::Core::Http::_detail::CurlConnectionPool::ExtractOrCreateCurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, bool) @ 0x00000000361f8355 5. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/curl/curl.cpp:351: Azure::Core::Http::CurlTransport::Send(Azure::Core::Http::Request&, Azure::Core::Context const&) @ 0x00000000361f6fcc 6. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/transport_policy.cpp:121: Azure::Core::Http::Policies::_internal::TransportPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036235b50 7. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/log_policy.cpp:114: Azure::Core::Http::Policies::_internal::LogPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x00000000362136e1 8. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/request_activity_policy.cpp:110: Azure::Core::Http::Policies::_internal::RequestActivityPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036233962 9. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/shared_key_policy.hpp:36: Azure::Storage::_internal::SharedKeyPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036242688 10. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_per_retry_policy.cpp:57: Azure::Storage::_internal::StoragePerRetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003628e5df 11. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_switch_to_secondary_policy.cpp:36: Azure::Storage::_internal::StorageSwitchToSecondaryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003628ea75 12. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/retry_policy.cpp:146: Azure::Core::Http::Policies::_internal::RetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036232358 13. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/telemetry_policy.cpp:23: Azure::Core::Http::Policies::_internal::TelemetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036235f23 14. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/policies/policy.hpp:453: Azure::Core::Http::Policies::_internal::RequestIdPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036228bda 15. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/storage_service_version_policy.hpp:34: Azure::Storage::_internal::StorageServiceVersionPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x00000000362429ea 16. ./contrib/azure/sdk/core/azure-core/inc/azure/core/internal/http/pipeline.hpp:230: Azure::Storage::Blobs::_detail::BlobContainerClient::GetProperties(Azure::Core::Http::_internal::HttpPipeline&, Azure::Core::Url const&, Azure::Storage::Blobs::_detail::BlobContainerClient::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) @ 0x000000003625f6ee 17. ./build_docker/./contrib/azure/sdk/storage/azure-storage-blobs/src/blob_container_client.cpp:324: Azure::Storage::Blobs::BlobContainerClient::GetProperties(Azure::Storage::Blobs::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) const @ 0x000000003624a610 18. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:105: DB::AzureBlobStorage::ContainerClientWrapper::GetProperties() const @ 0x000000002b8abff5 19. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:319: DB::AzureBlobStorage::getContainerClient(DB::AzureBlobStorage::ConnectionParams const&, bool) @ 0x000000002b8af4c9 20. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageFactory.cpp:308: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool) @ 0x000000002ca23fa8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ca20d34 22. ./build_docker/./src/Disks/ObjectStorages/RegisterDiskObjectStorage.cpp:27: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002ca1fcd3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 24. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 25. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fe4a1c 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4af6d1 27. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fe3403 28. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fe56de 29. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fe52ad 30. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fe4268 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030fa2324 2025.07.13 02:32:52.214891 [ 29256 ] {} TCPHandler: Code: 1001. DB::Exception: Azure::Core::Http::TransportException: Fail to get a new connection for: http://localhost:10000. Could not connect to server. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:32: std::runtime_error::runtime_error(String const&) @ 0x0000000038fb32de 2. ./build_docker/./contrib/azure/sdk/core/azure-core/src/exception.cpp:20: Azure::Core::RequestFailedException::RequestFailedException(String const&) @ 0x00000000362058ae 3. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/http.hpp:66: Azure::Core::Http::CurlConnection::CurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, String const&, String const&) @ 0x0000000036201215 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: Azure::Core::Http::_detail::CurlConnectionPool::ExtractOrCreateCurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, bool) @ 0x00000000361f8355 5. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/curl/curl.cpp:351: Azure::Core::Http::CurlTransport::Send(Azure::Core::Http::Request&, Azure::Core::Context const&) @ 0x00000000361f6fcc 6. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/transport_policy.cpp:121: Azure::Core::Http::Policies::_internal::TransportPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036235b50 7. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/log_policy.cpp:114: Azure::Core::Http::Policies::_internal::LogPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x00000000362136e1 8. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/request_activity_policy.cpp:110: Azure::Core::Http::Policies::_internal::RequestActivityPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036233962 9. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/shared_key_policy.hpp:36: Azure::Storage::_internal::SharedKeyPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036242688 10. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_per_retry_policy.cpp:57: Azure::Storage::_internal::StoragePerRetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003628e5df 11. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_switch_to_secondary_policy.cpp:36: Azure::Storage::_internal::StorageSwitchToSecondaryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003628ea75 12. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/retry_policy.cpp:146: Azure::Core::Http::Policies::_internal::RetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036232358 13. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/telemetry_policy.cpp:23: Azure::Core::Http::Policies::_internal::TelemetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036235f23 14. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/policies/policy.hpp:453: Azure::Core::Http::Policies::_internal::RequestIdPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036228bda 15. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/storage_service_version_policy.hpp:34: Azure::Storage::_internal::StorageServiceVersionPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x00000000362429ea 16. ./contrib/azure/sdk/core/azure-core/inc/azure/core/internal/http/pipeline.hpp:230: Azure::Storage::Blobs::_detail::BlobContainerClient::GetProperties(Azure::Core::Http::_internal::HttpPipeline&, Azure::Core::Url const&, Azure::Storage::Blobs::_detail::BlobContainerClient::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) @ 0x000000003625f6ee 17. ./build_docker/./contrib/azure/sdk/storage/azure-storage-blobs/src/blob_container_client.cpp:324: Azure::Storage::Blobs::BlobContainerClient::GetProperties(Azure::Storage::Blobs::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) const @ 0x000000003624a610 18. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:105: DB::AzureBlobStorage::ContainerClientWrapper::GetProperties() const @ 0x000000002b8abff5 19. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:319: DB::AzureBlobStorage::getContainerClient(DB::AzureBlobStorage::ConnectionParams const&, bool) @ 0x000000002b8af4c9 20. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageFactory.cpp:308: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool) @ 0x000000002ca23fa8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ca20d34 22. ./build_docker/./src/Disks/ObjectStorages/RegisterDiskObjectStorage.cpp:27: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002ca1fcd3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 24. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 25. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fe4a1c 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4af6d1 27. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fe3403 28. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fe56de 29. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fe52ad 30. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fe4268 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030fa2324 2025.07.13 02:32:52.694185 [ 34259 ] {f291d40e-ba62-4e1a-b7f0-a6fa3003b1de} executeQuery: Code: 60. DB::Exception: Table test_z7erpvqi.test_azure_mt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43642) (comment: 03008_azure_plain_rewritable_with_empty_col.sh) (query 1, line 1) (in query: optimize table test_azure_mt final), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:52.709277 [ 34259 ] {} TCPHandler: Code: 60. DB::Exception: Table test_z7erpvqi.test_azure_mt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e330d5d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:52.807665 [ 6967 ] {} test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:32:53.047719 [ 6967 ] {} DatabaseCatalog: Cannot drop table test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:53.092719 [ 2824 ] {2125644e-9fa2-4c43-b416-55eda18f0221} executeQuery: Code: 60. DB::Exception: Table test_z7erpvqi.test_azure_mt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43644) (comment: 03008_azure_plain_rewritable_with_empty_col.sh) (query 1, line 2) (in query: insert into test_azure_mt (a, b) select number, number from numbers_mt(10000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:209: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002dce6f9b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1436: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2addbf 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:53.126696 [ 2824 ] {} TCPHandler: Code: 60. DB::Exception: Table test_z7erpvqi.test_azure_mt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:209: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002dce6f9b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1436: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2addbf 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:53.482136 [ 34340 ] {7b627b04-dc66-44fe-a25b-a1c84a0cd38a} executeQuery: Code: 36. DB::Exception: Cannot replace partition '0' because part '0_1_1_0' has inconsistent granularity with table. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58348) (comment: 02422_insert_different_granularity.sql) (query 28, line 81) (in query: ALTER TABLE table_two REPLACE PARTITION 0 FROM table_one;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000023e03bef 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2272: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003120dafb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e8ac 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:53.486568 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: Cannot replace partition '0' because part '0_1_1_0' has inconsistent granularity with table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000023e03bef 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2272: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003120dafb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e8ac 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:32:53.787428 [ 34277 ] {7e4d381e-8a1c-4357-957b-4aeb69d6656a} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 518, line 173) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:53.800519 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:54.364137 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:54.370822 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:32:54.821899 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:55.121526 [ 34277 ] {04ae595f-8867-424b-8c04-7dd60fa91883} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 524, line 175) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:55.133435 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:55.809297 [ 5105 ] {31d119a3-66fe-40b5-83cc-85d0d06200d2} DynamicQueryHandler: Code: 69. DB::Exception: Chunk size exceeded the limit (max size: 107374182400). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:36: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000316f80a6 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000316f853c 7. DB::ReadBuffer::next() @ 0x0000000017e75832 8. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000023b6295d 9. DB::ReadBuffer::next() @ 0x0000000017e75832 10. ./src/IO/ReadBuffer.h:96: DB::HTMLForm::MultipartReadBuffer::skipToNextBoundary() @ 0x00000000316ed438 11. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:197: DB::HTMLForm::readMultipart(DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x00000000316ec228 12. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:110: DB::HTMLForm::load(Poco::Net::HTTPRequest const&, DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x00000000316eacfa 13. ./build_docker/./src/Server/HTTPHandler.cpp:836: DB::DynamicQueryHandler::getQuery(DB::HTTPServerRequest&, DB::HTMLForm&, std::shared_ptr) @ 0x00000000315c9c87 14. ./build_docker/./src/Server/HTTPHandler.cpp:471: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf4b8 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:55.848156 [ 5105 ] {31d119a3-66fe-40b5-83cc-85d0d06200d2} void DB::drainRequestIfNeeded(HTTPServerRequest &, HTTPServerResponse &): Cannot read remaining request body during exception handling. Set keep alive to false on the response.: Code: 408. DB::Exception: Unexpected data instead of HTTP chunk header. (BAD_REQUEST_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:25: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000316f82fd 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000316f853c 7. DB::ReadBuffer::next() @ 0x0000000017e75832 8. ./src/IO/ReadBuffer.h:96: DB::drainRequestIfNeeded(DB::HTTPServerRequest&, DB::HTTPServerResponse&) @ 0x000000003170cb9f 9. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:270: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x0000000031703534 10. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000315c3822 11. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c7c3e 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:55.897745 [ 5105 ] {31d119a3-66fe-40b5-83cc-85d0d06200d2} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:33306). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:105: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000023caf5b7 5. ./src/Server/HTTP/HTTPServerResponse.h:196: DB::HTTPWriteBuffer::nextImplChunked() @ 0x00000000317068b0 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:145: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003170145e 7. DB::WriteBuffer::next() @ 0x0000000017cd6383 8. ./src/IO/WriteBuffer.h:127: DB::HTTPWriteBuffer::finalizeImpl() @ 0x0000000031706223 9. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:217: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x0000000031702777 10. ./build_docker/./src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x0000000023b67a57 11. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:282: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003170384f 12. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000315c3822 13. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c7c3e 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:56.157344 [ 57041 ] {d94725b0-bfda-4f1e-80b4-03c6b9550f27} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43716) (comment: 01428_h3_range_check.sql) (query 1, line 3) (in query: SELECT h3ToChildren(599405990164561919, 100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c179b14 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:32:56.162976 [ 57041 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c179b14 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:32:56.262167 [ 34277 ] {9274712f-921b-459a-8a81-482457d8ef75} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 530, line 177) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:56.266601 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:56.294441 [ 57041 ] {153d396b-47a2-4fd4-84d6-476774939184} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToParent is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToParent(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43716) (comment: 01428_h3_range_check.sql) (query 2, line 4) (in query: SELECT h3ToParent(599405990164561919, 100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::(anonymous namespace)::FunctionH3ToParent::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c17e6ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:32:56.312231 [ 57041 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToParent is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToParent(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::(anonymous namespace)::FunctionH3ToParent::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c17e6ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:32:56.699129 [ 34277 ] {c647dbe9-0922-43d8-9470-880b33fe7d5f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 533, line 178) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:56.716165 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:32:57.918586 [ 57041 ] {3c406782-1730-4aee-8059-5a48a4412977} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 01710_projections.sql) (query 5, line 9) (in query: select * from projection_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:57.923130 [ 57041 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:58.182045 [ 57041 ] {eb98ebfb-87eb-4f4a-a4c7-6cc7c842a40f} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43734) (comment: 01710_projections.sql) (query 6, line 10) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_m;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:58.205354 [ 57041 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:32:59.015058 [ 5732 ] {d3b421f6-44cd-40cc-9f9a-c87e5d2f615e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33804) (comment: 02456_alter-nullable-column-bag-2.sql) (in query: DROP DATABASE IF EXISTS test_t3pkde5z SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:32:59.021123 [ 5732 ] {d3b421f6-44cd-40cc-9f9a-c87e5d2f615e} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:59.163125 [ 5105 ] {586e5fd8-5d55-4a0f-bbe8-47e677cd892f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33816) (comment: 02456_alter-nullable-column-bag-2.sql) (in query: DROP DATABASE IF EXISTS test_t3pkde5z SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:32:59.178143 [ 5105 ] {586e5fd8-5d55-4a0f-bbe8-47e677cd892f} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:32:59.770836 [ 6022 ] {c8fb5c93-4ab7-48d3-99a6-eb7f2d2574a3} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59218) (comment: 01762_deltasumtimestamp_datetime64.sh) (query 1, line 1) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002458f667 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:32:59.799245 [ 6022 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871946f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002458f667 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:33:00.484237 [ 6933 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:33:07: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:00.657656 [ 6022 ] {ee6a80cd-bbd3-4686-be52-4851a54e0747} 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.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53070) (in query: select 1 in (1, 1, ... (truncated 948624 characters)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:33:00.659764 [ 6022 ] {ee6a80cd-bbd3-4686-be52-4851a54e0747} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0b563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033082972 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000033082a0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a8d72 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:01.692102 [ 6899 ] {} test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:33:03.343753 [ 6899 ] {} DatabaseCatalog: Cannot drop table test_ljiqkcgz.alter_table (4e36ba87-7288-444b-88e6-2db2be2415c0). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:03.546663 [ 34260 ] {f906b2d2-a788-4433-be03-06323ad61e99} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 18, line 20) (in query: select makeDate(cast(1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.584580 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.724880 [ 34260 ] {fa612a52-21ff-474b-9637-3cf3c0e23d31} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 19, line 21) (in query: select makeDate(cast(-1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.731610 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.815390 [ 34260 ] {e778ccf7-02b1-43f3-bbd1-ebc4fa113a27} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 20, line 22) (in query: select makeDate(cast(1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.836874 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.952283 [ 34260 ] {966f0a5d-1d74-4814-8c88-b8e15fb37639} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 21, line 23) (in query: select makeDate(cast(-1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:03.961952 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.054202 [ 34260 ] {a7d01ab1-8fd2-4f41-80c9-801325375b67} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 22, line 24) (in query: select makeDate(cast(1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.072914 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.312101 [ 34260 ] {9bafab42-ef73-4d2b-892c-f05fe79b57c7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 23, line 25) (in query: select makeDate(cast(-1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.318248 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.442936 [ 34260 ] {fb000ebf-22b1-47f7-9ad4-506bf604e46b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 24, line 26) (in query: select makeDate(cast(1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.477711 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.611776 [ 34260 ] {f678eac2-594d-433e-9c5a-9d89b25b9b01} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 25, line 27) (in query: select makeDate(cast(-1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.628660 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:04.857596 [ 6024 ] {9aafceee-6b1c-43a1-aa6b-b937e115a3d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=844). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58364) (comment: 00233_position_function_family.sql) (query 147, line 174) (in query: select 1 = positionCaseInsensitive('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:04.884642 [ 6024 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=844). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:06.346600 [ 57042 ] {ba2b54c9-c7c0-40de-bee3-82fafc6a96ee} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59262) (comment: 03223_analyzer_with_cube_fuzz.sql) (query 8, line 12) (in query: SELECT 1 * 1000.0001, (count(1.) = -2147483647) AND (count(a) = 1.1920928955078125e-7) AND (count(val) = 1048577) AND (sum(val) = ((NULL * 1048576) / -9223372036854775807)) AND (sum(a) = ((9223372036854775806 * 10000000000.) / 1048575)) FROM ( SELECT a, val FROM t1 FULL OUTER JOIN t2 ON (t1.a = t2.key) OR (1 * inf) OR (t1.b = t2.key) ) GROUP BY '65537' WITH CUBE FORMAT Null SETTINGS max_block_size = 100, join_use_nulls = 1, max_execution_time = 1., max_result_rows = 0, max_result_bytes = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x000000002dde53bd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2060: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda38be 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 11. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:33:06.362810 [ 57042 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x000000002dde53bd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2060: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda38be 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1201: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda7691 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 11. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:33:06.390029 [ 3816 ] {4e1a4779-e4c2-4755-a8c4-cad34876297a} executeQuery: Code: 57. DB::Exception: Table test_aig2723c.check_codec already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59292) (comment: 01390_check_table_codec.sql) (query 7, line 11) (in query: CREATE TABLE check_codec (`a` Int, `b` Int CODEC(Delta, ZSTD)) ENGINE = MergeTree ORDER BY a SETTINGS min_bytes_for_wide_part = '10M', index_granularity = 47654, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 106, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 499999552, compact_parts_max_granules_to_buffer = 203, compact_parts_merge_max_bytes_to_prefetch_part = 24677006, merge_max_block_size = 7650, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 659331, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7621783701, index_granularity_bytes = 17644416, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 35, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 77938, primary_key_compress_block_size = 27889, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:06.411294 [ 3816 ] {} TCPHandler: Code: 57. DB::Exception: Table test_aig2723c.check_codec already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:07.168663 [ 46286 ] {916a56ef-8d44-45ea-9880-d0b229148af5} executeQuery: Code: 36. DB::Exception: Disk `s3_disk` already exists and is described by the config. It is impossible to redefine it.: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_15`, disk = s3_disk). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59330) (comment: 02808_custom_disk_with_user_defined_name.sh) (query 2, line 3) (in query: CREATE TABLE test (`a` Int32, `b` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_15`, disk = s3_disk), index_granularity = 5972, min_bytes_for_wide_part = 452920731, ratio_of_defaults_for_sparse_serialization = 0.7760475277900696, replace_long_file_name_to_hash = false, max_file_name_length = 75, min_bytes_for_full_part_storage = 523711383, compact_parts_max_bytes_to_buffer = 151448739, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 22644068, merge_max_block_size = 5332, old_parts_lifetime = 322., prefer_fetch_merged_part_size_threshold = 2765335737, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 64, min_merge_bytes_to_use_direct_io = 2639118804, index_granularity_bytes = 3197212, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 10, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 49365, primary_key_compress_block_size = 66041, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Disks/DiskFromAST.cpp:65: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fe3bb5 6. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fe56de 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fe52ad 8. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fe4268 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030fa2324 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030fa661b 11. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c6de1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:07.191562 [ 46286 ] {} TCPHandler: Code: 36. DB::Exception: Disk `s3_disk` already exists and is described by the config. It is impossible to redefine it.: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_15`, disk = s3_disk). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Disks/DiskFromAST.cpp:65: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fe3bb5 6. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fe56de 7. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fe52ad 8. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fe4268 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030fa2324 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030fa661b 11. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c6de1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:07.884676 [ 5480 ] {e68db306-6328-42e1-89dc-7dc0785309e1} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58564) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_1t7rxj0p.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 2025.07.13 02:33:07.893307 [ 5480 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 2025.07.13 02:33:07.973195 [ 46294 ] {4ba3aac5-23c0-4142-9d2d-34d723eb133e} executeQuery: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/2ce/2ce35551-c370-4e32-8cdf-026e783fb33a/shard1_replica1/1.bin. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59290) (comment: 03030_system_flush_distributed_settings.sql) (query 15, line 20) (in query: system flush distributed dist_in;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000030ab0074 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x0000000030aac487 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000030aa828e 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:633: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000030a9df29 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a993e3 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:07.983775 [ 46294 ] {} TCPHandler: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/2ce/2ce35551-c370-4e32-8cdf-026e783fb33a/shard1_replica1/1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000030ab0074 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x0000000030aac487 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000030aa828e 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:633: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000030a9df29 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a993e3 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000303b5d5a 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000002e30dcac 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6fd7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.193881 [ 34277 ] {4b5376bd-2f92-4d4a-b233-32be04621517} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 563, line 188) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.210135 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.722092 [ 57042 ] {356f87d1-3607-496e-b2ec-868ea10c56df} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 32.10 MiB (attempt to allocate chunk of 16.00 MiB), maximum: 0.00 B. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59374) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_1t7rxj0p.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cbf514 10. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cbec91 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c612348 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 13. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x00000000317babfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2234: DB::TCPHandler::processData(DB::QueryState&, bool) @ 0x00000000316d02a2 15. ./build_docker/./src/Server/TCPHandler.cpp:984: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x00000000316ce9a2 16. ./build_docker/./src/Server/TCPHandler.cpp:932: DB::TCPHandler::receivePacketsExpectDataConcurrentWithExecutor(DB::QueryState&) @ 0x00000000316cde1c 17. ./build_docker/./src/Server/TCPHandler.cpp:1119: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0c18 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.783204 [ 34277 ] {de15d5ad-22db-41ff-9803-2e4752838df3} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 566, line 189) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.789640 [ 57042 ] {356f87d1-3607-496e-b2ec-868ea10c56df} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 101. DB::Exception: Unexpected packet Hello received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:1833: DB::TCPHandler::processUnexpectedHello() @ 0x00000000316c6579 6. ./build_docker/./src/Server/TCPHandler.cpp:972: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x00000000316ceca6 7. ./build_docker/./src/Server/TCPHandler.cpp:1031: DB::TCPHandler::skipData(DB::QueryState&) @ 0x00000000316c39fb 8. ./build_docker/./src/Server/TCPHandler.cpp:830: DB::TCPHandler::runImpl() @ 0x00000000316add8e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:08.795675 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.796372 [ 57042 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 32.10 MiB (attempt to allocate chunk of 16.00 MiB), maximum: 0.00 B. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cbf514 10. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cbec91 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c612348 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 13. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x00000000317babfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2234: DB::TCPHandler::processData(DB::QueryState&, bool) @ 0x00000000316d02a2 15. ./build_docker/./src/Server/TCPHandler.cpp:984: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x00000000316ce9a2 16. ./build_docker/./src/Server/TCPHandler.cpp:932: DB::TCPHandler::receivePacketsExpectDataConcurrentWithExecutor(DB::QueryState&) @ 0x00000000316cde1c 17. ./build_docker/./src/Server/TCPHandler.cpp:1119: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0c18 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.829932 [ 46294 ] {7fda530f-205b-4424-b3d9-2146cf789d7a} executeQuery: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory tracker: fault injected. Would use 32.10 MiB (attempt to allocate chunk of 16.00 MiB), maximum: 0.00 B. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cbf514 10. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cbec91 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c612348 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 13. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x00000000317babfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2234: DB::TCPHandler::processData(DB::QueryState&, bool) @ 0x00000000316d02a2 15. ./build_docker/./src/Server/TCPHandler.cpp:984: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x00000000316ce9a2 16. ./build_docker/./src/Server/TCPHandler.cpp:932: DB::TCPHandler::receivePacketsExpectDataConcurrentWithExecutor(DB::QueryState&) @ 0x00000000316cde1c 17. ./build_docker/./src/Server/TCPHandler.cpp:1119: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0c18 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/2ce/2ce35551-c370-4e32-8cdf-026e783fb33a/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59290) (comment: 03030_system_flush_distributed_settings.sql) (query 16, line 21) (in query: system flush distributed dist_in settings max_memory_usage=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:110: DB::RemoteInserter::write(DB::Block) @ 0x0000000030aafc4c 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertHelpers.cpp:66: DB::writeAndConvert(DB::RemoteInserter&, DB::DistributedAsyncInsertHeader const&, DB::ReadBufferFromFile&) @ 0x0000000030ab34d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertHelpers.cpp:0: DB::writeRemoteConvert(DB::DistributedAsyncInsertHeader const&, DB::RemoteInserter&, bool, DB::ReadBufferFromFile&, std::shared_ptr) @ 0x0000000030ab43d9 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:282: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x0000000030aabf52 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000030aa828e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000030a9bf90 12. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a993e3 13. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 15. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:33:08.837492 [ 46294 ] {} TCPHandler: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory tracker: fault injected. Would use 32.10 MiB (attempt to allocate chunk of 16.00 MiB), maximum: 0.00 B. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cbf514 10. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cbec91 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c612348 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 13. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x00000000317babfc 14. ./build_docker/./src/Server/TCPHandler.cpp:2234: DB::TCPHandler::processData(DB::QueryState&, bool) @ 0x00000000316d02a2 15. ./build_docker/./src/Server/TCPHandler.cpp:984: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x00000000316ce9a2 16. ./build_docker/./src/Server/TCPHandler.cpp:932: DB::TCPHandler::receivePacketsExpectDataConcurrentWithExecutor(DB::QueryState&) @ 0x00000000316cde1c 17. ./build_docker/./src/Server/TCPHandler.cpp:1119: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0c18 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/2ce/2ce35551-c370-4e32-8cdf-026e783fb33a/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:110: DB::RemoteInserter::write(DB::Block) @ 0x0000000030aafc4c 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertHelpers.cpp:66: DB::writeAndConvert(DB::RemoteInserter&, DB::DistributedAsyncInsertHeader const&, DB::ReadBufferFromFile&) @ 0x0000000030ab34d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertHelpers.cpp:0: DB::writeRemoteConvert(DB::DistributedAsyncInsertHeader const&, DB::RemoteInserter&, bool, DB::ReadBufferFromFile&, std::shared_ptr) @ 0x0000000030ab43d9 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:282: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x0000000030aabf52 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000030aa828e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000030a9bf90 12. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a993e3 13. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 15. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000303b5d5a 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000002e30dcac 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x000000002e2f6fd7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:33:09.144566 [ 5476 ] {a8179929-3af9-494c-9296-28957a64a21b} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2299, 12, 31, 23, 59, 59, 999999999, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59308) (comment: 02245_make_datetime64.sql) (query 14, line 16) (in query: select makeDateTime64(2299, 12, 31, 23, 59, 59, 999999999, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000017e3e0f6 6. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcca4e6 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:33:09.157256 [ 5476 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2299, 12, 31, 23, 59, 59, 999999999, 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000017e3e0f6 6. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcca4e6 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:33:09.487446 [ 5476 ] {503cdfbe-76cc-484f-83bb-2759c4468e49} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2262, 4, 11, 23, 47, 16, 854775808, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59308) (comment: 02245_make_datetime64.sql) (query 16, line 18) (in query: select makeDateTime64(2262, 4, 11, 23, 47, 16, 854775808, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000017e3e152 6. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcca4e6 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:33:09.505396 [ 5476 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT makeDateTime64(2262, 4, 11, 23, 47, 16, 854775808, 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000017e3e152 6. DB::(anonymous namespace)::FunctionMakeDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcca4e6 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:33:09.577745 [ 3815 ] {823cf8d5-6723-408e-baac-6543bd5e380a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_1t7rxj0p.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 2025.07.13 02:33:09.601586 [ 3815 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 2025.07.13 02:33:09.824536 [ 6875 ] {6878dd02-bdce-4703-987d-49f08650ee9d} StorageDistributed (dist_in): Cannot flush: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/2ce/2ce35551-c370-4e32-8cdf-026e783fb33a/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000030ab0074 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x0000000030aac487 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000030aa828e 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000030a9bf90 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a993e3 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1728: DB::StorageDistributed::flushAndPrepareForShutdown() @ 0x00000000303b3607 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 8. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb6fe2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:10.288379 [ 34260 ] {433fc86e-01ae-4daa-a31f-5ecf8714c1e7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 58, line 63) (in query: select makeDate('1980', '10', '20');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.301147 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.395265 [ 34260 ] {462a5dd8-b2d9-416d-a25f-2d33784f7fd1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 59, line 64) (in query: select makeDate('-1980', 3, 17);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.400320 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.429264 [ 5382 ] {f7e882ee-8ded-47c6-9329-5152dd81a9be} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50906) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_1t7rxj0p.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 2025.07.13 02:33:10.465425 [ 5382 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 2025.07.13 02:33:10.466180 [ 3816 ] {6878dd02-bdce-4703-987d-49f08650ee9d} StorageDistributed (dist_in): Cannot flush: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.20 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_1t7rxj0p.mv (b7947771-161a-4d66-baec-460a3e085aaa). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000017cd5f97 12. DB::WriteBuffer::next() @ 0x0000000017cd6383 13. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x0000000023b67254 14. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000017d49129 15. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1f52bd 16. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1ee4c6 17. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b049dea 18. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b048a63 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 24. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adc3893 25. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 29. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 30. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 31. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/2ce/2ce35551-c370-4e32-8cdf-026e783fb33a/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000030ab0074 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x0000000030aac487 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000030aa828e 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000030a9bf90 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x0000000030a993e3 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000030a99215 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000303b41ae 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1728: DB::StorageDistributed::flushAndPrepareForShutdown() @ 0x00000000303b3607 7. ./src/Storages/IStorage.h:565: DB::IStorage::flushAndShutdown(bool) @ 0x000000002dcba6bb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:302: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2c3c 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:10.540137 [ 34260 ] {e25adeb8-5a04-4cf9-b1eb-ebc8514ee22e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 60, line 66) (in query: select makeDate('aa', 3, 24);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.563466 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.604792 [ 36824 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:33:16: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:10.627611 [ 34260 ] {0e149e81-3807-450b-b3d7-665d25c1d4be} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 61, line 67) (in query: select makeDate(1994, 'aa', 24);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.639687 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.709407 [ 34260 ] {bcc14131-7464-4ad5-bcbc-ceeb9e2ad8c2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 62, line 68) (in query: select makeDate(1984, 3, 'aa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:10.714678 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc4845 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:33:11.266035 [ 5476 ] {93c73cc3-6759-4989-b779-f61a485c4db3} executeQuery: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, 10, 'CET'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59308) (comment: 02245_make_datetime64.sql) (query 28, line 31) (in query: select makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, 10, 'CET');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x000000001dccb59d 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccae18 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:11.290153 [ 5476 ] {} TCPHandler: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, 10, 'CET'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x000000001dccb59d 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccae18 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:11.453993 [ 5476 ] {2d404961-699d-4dbe-84a1-c50cd7159182} executeQuery: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, -1, 'CET'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59308) (comment: 02245_make_datetime64.sql) (query 29, line 32) (in query: select makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, -1, 'CET');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x000000001dccb59d 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccae18 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:11.476394 [ 5476 ] {} TCPHandler: Code: 69. DB::Exception: Argument 'precision' for function makeDateTime64 must be in range [0, 9]: In scope SELECT makeDateTime64(1991, 8, 24, 21, 4, 0, 1234, -1, 'CET'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDateTimeBase::extractPrecision(DB::ColumnWithTypeAndName const&) const @ 0x000000001dccb59d 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccae18 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:12.593171 [ 34260 ] {9054bb9f-25bb-4a44-b5ae-6ca1b4e5c106} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 72, line 81) (in query: select makeDate(1980);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:12.604624 [ 34260 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:12.702880 [ 34260 ] {5f08fae5-980a-4e8c-980a-056f72f0d617} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59228) (comment: 02242_make_date.sql) (query 73, line 82) (in query: select makeDate(1980, 1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:12.720425 [ 34260 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc498e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:13.347554 [ 5476 ] {7b147bcb-5f14-4733-9146-d96360dc6e7a} executeQuery: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime64(1984, 1, 1, 0, 0, 0, 0, 9, 'not a timezone'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59308) (comment: 02245_make_datetime64.sql) (query 37, line 41) (in query: select makeDateTime64(1984, 1, 1, 0, 0, 0, 0, 9, 'not a timezone');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c4110d7 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, long&, String&) @ 0x000000001dcd0cfb 10. std::shared_ptr std::allocate_shared[abi:ne190107], long&, String&, 0>(std::allocator const&, long&, String&) @ 0x000000001dcd0b06 11. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccaf1b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:33:13.358738 [ 5476 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime64(1984, 1, 1, 0, 0, 0, 0, 9, 'not a timezone'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c9502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c4635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c410588 8. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c4110d7 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, long&, String&) @ 0x000000001dcd0cfb 10. std::shared_ptr std::allocate_shared[abi:ne190107], long&, String&, 0>(std::allocator const&, long&, String&) @ 0x000000001dcd0b06 11. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccaf1b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:33:16.268397 [ 46285 ] {efaff080-e6ed-4c56-a86f-c0fe35c824a8} executeQuery: Code: 415. DB::Exception: Cannot create a replica of the table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table7, because the last replica of the table was dropped right now. (ALL_REPLICAS_LOST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51012) (comment: 02122_4letter_words_stress_zookeeper.sh) (query 1, line 1) (in query: CREATE TABLE test_table7 (`key` UInt64, `value1` UInt8, `value2` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table7', '0') ORDER BY key SETTINGS index_granularity = 2624, min_bytes_for_wide_part = 146415410, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 69, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 419471814, compact_parts_max_granules_to_buffer = 95, compact_parts_merge_max_bytes_to_prefetch_part = 14023253, merge_max_block_size = 19392, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7100844694, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10251450550, index_granularity_bytes = 7796051, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 46391, primary_key_compress_block_size = 78084, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1187: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000305ba45a 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x000000003059c684 7. ./build_docker/./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&) @ 0x0000000030597480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:16.332515 [ 46285 ] {} TCPHandler: Code: 415. DB::Exception: Cannot create a replica of the table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table7, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1187: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000305ba45a 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x000000003059c684 7. ./build_docker/./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&) @ 0x0000000030597480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:18.123296 [ 5826 ] {fa38d086-1672-4359-8d98-56a167ebc182} executeQuery: Code: 141. DB::Exception: Storage test_7.modify_sample doesn't support sampling. (SAMPLING_NOT_SUPPORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51024) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0ba84 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5365: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b2ed 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:18.143029 [ 5826 ] {} TCPHandler: Code: 141. DB::Exception: Storage test_7.modify_sample doesn't support sampling. (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0ba84 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5365: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b2ed 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:19.513130 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:19.573867 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:19.664718 [ 5476 ] {7f723aa2-820a-44b1-9957-6458f89d889a} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 7th argument 'precision' to function 'makeDateTime64'. Expected: const Number, got: UInt8: In scope SELECT makeDateTime64(year, 1, 1, 1, 0, 0, 0, precision, timezone) FROM (SELECT 1984 AS year, 5 AS precision, 'UTC' AS timezone UNION ALL SELECT 1985 AS year, 5 AS precision, 'UTC' AS timezone). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59308) (comment: 02245_make_datetime64.sql) (query 76, line 88) (in query: select makeDateTime64(year, 1, 1, 1, 0, 0, 0, precision, timezone) from ( select 1984 as year, 5 as precision, 'UTC' as timezone union all select 1985 as year, 5 as precision, 'UTC' as timezone );), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccacfa 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:19.683704 [ 5476 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 7th argument 'precision' to function 'makeDateTime64'. Expected: const Number, got: UInt8: In scope SELECT makeDateTime64(year, 1, 1, 1, 0, 0, 0, precision, timezone) FROM (SELECT 1984 AS year, 5 AS precision, 'UTC' AS timezone UNION ALL SELECT 1985 AS year, 5 AS precision, 'UTC' AS timezone). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::(anonymous namespace)::FunctionMakeDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccacfa 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:33:20.033743 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:20.123602 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:20.442742 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:20.528706 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:20.652244 [ 7092 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:33:32: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:20.793376 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:20.852156 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:21.066361 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:21.213300 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:21.458359 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:21.514463 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:21.914788 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): Removing leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 (this might take several minutes) 2025.07.13 02:33:21.976801 [ 6022 ] {b6632e98-a3d5-47b3-a798-bc4f4e808d5c} test_15.test_table6 (e960b636-7e49-44eb-9ec9-3d4c272b8411): The leftovers from table /clickhouse/tables/02122_4letter_words_stress_zookeeper_test_15/test_table6 were removed by another replica 2025.07.13 02:33:22.183073 [ 57041 ] {907746c1-eb47-41a4-9ffe-3fcb538fb2c3} executeQuery: Code: 117. DB::Exception: Index 2 in Dictionary column is out of bounds, dictionary size is 2: (in file/uri /var/lib/clickhouse/user_files/test-02383-11678-31749/corrupted.arrow): While executing ArrowBlockInputFormat: While executing File. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50426) (comment: 02383_arrow_dict_special_cases.sh) (query 1, line 1) (in query: select * from file('/var/lib/clickhouse/user_files/test-02383-11678-31749/corrupted.arrow')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&&, unsigned long&&) @ 0x00000000318b5ecf 5. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:571: DB::ColumnWithTypeAndName DB::readColumnWithIndexesDataImpl>(std::shared_ptr&, String const&, long, char8_t, bool) @ 0x00000000318a77ab 6. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:656: DB::readNonNullableColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x000000003188e748 7. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1241: DB::readColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x000000003187b5f5 8. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1446: DB::ArrowColumnToCHColumn::arrowColumnsToCHChunk(std::unordered_map, std::equal_to, std::allocator>> const&, unsigned long, DB::BlockMissingValues*) @ 0x000000003187cf32 9. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1351: DB::ArrowColumnToCHColumn::arrowTableToCHChunk(std::shared_ptr const&, unsigned long, DB::BlockMissingValues*) @ 0x000000003187c603 10. ./build_docker/./src/Processors/Formats/Impl/ArrowBlockInputFormat.cpp:92: DB::ArrowBlockInputFormat::read() @ 0x00000000318607f2 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303ea300 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:33:22.212833 [ 57041 ] {} TCPHandler: Code: 117. DB::Exception: Index 2 in Dictionary column is out of bounds, dictionary size is 2: (in file/uri /var/lib/clickhouse/user_files/test-02383-11678-31749/corrupted.arrow): While executing ArrowBlockInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&&, unsigned long&&) @ 0x00000000318b5ecf 5. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:571: DB::ColumnWithTypeAndName DB::readColumnWithIndexesDataImpl>(std::shared_ptr&, String const&, long, char8_t, bool) @ 0x00000000318a77ab 6. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:656: DB::readNonNullableColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x000000003188e748 7. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1241: DB::readColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x000000003187b5f5 8. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1446: DB::ArrowColumnToCHColumn::arrowColumnsToCHChunk(std::unordered_map, std::equal_to, std::allocator>> const&, unsigned long, DB::BlockMissingValues*) @ 0x000000003187cf32 9. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1351: DB::ArrowColumnToCHColumn::arrowTableToCHChunk(std::shared_ptr const&, unsigned long, DB::BlockMissingValues*) @ 0x000000003187c603 10. ./build_docker/./src/Processors/Formats/Impl/ArrowBlockInputFormat.cpp:92: DB::ArrowBlockInputFormat::read() @ 0x00000000318607f2 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303ea300 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:33:24.928789 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:26.340393 [ 5826 ] {dfd8277a-2fee-4e9d-8e17-22e9fa1a3c7f} executeQuery: Code: 141. DB::Exception: Storage test_7.modify_sample_replicated doesn't support sampling. (SAMPLING_NOT_SUPPORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51024) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0ba84 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5365: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b2ed 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:26.343353 [ 5826 ] {} TCPHandler: Code: 141. DB::Exception: Storage test_7.modify_sample_replicated doesn't support sampling. (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0ba84 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5365: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b2ed 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:28.242675 [ 5826 ] {4aab7bc5-b562-4dff-9d2f-5ced8784f377} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=7): While reading or decompressing /var/lib/clickhouse/store/cc6/cc6c26e1-8a85-4ac6-9451-197556ac8218/20000101_10_10_0/x.cmrk2 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51024) (comment: 01430_modify_sample_by_zookeeper_long.sql) (query 15, line 26) (in query: ATTACH TABLE modify_sample_replicated;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000030f05374 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:232: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000030f03b9a 18. ./build_docker/./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()() @ 0x0000000030f0807b 19. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task ()>::operator()() @ 0x0000000030f0bd12 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:28.416181 [ 5826 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=7): While reading or decompressing /var/lib/clickhouse/store/cc6/cc6c26e1-8a85-4ac6-9451-197556ac8218/20000101_10_10_0/x.cmrk2 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000030f05374 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:232: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000030f03b9a 18. ./build_docker/./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()() @ 0x0000000030f0807b 19. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task ()>::operator()() @ 0x0000000030f0bd12 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:243: void std::__function::__policy_invoker::__call_impl[abi:ne190107]> const&, DB::MarkCache*) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030dddf91 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:226: DB::MergeTreeDataPartWide::loadMarksToCache(std::vector> const&, DB::MarkCache*) const @ 0x0000000030ddaba3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 12. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2499: DB::MergeTreeData::prewarmCaches(ThreadPoolImpl>&, std::shared_ptr, std::shared_ptr) @ 0x0000000030cae522 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:532: 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&) @ 0x0000000030596d3b 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:33:28.698459 [ 34277 ] {a319a400-8c10-484f-be2e-44617b8597b0} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 608, line 203) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:28.702750 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:28.948616 [ 3815 ] {890ab3cc-5aa6-4b8c-9e9f-54f7d81bc755} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50918) (comment: 02552_siphash128_reference.sql) (query 129, line 203) (in query: select sipHash128ReferenceKeyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4b57 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158b95 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158898 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:33:28.952575 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4b57 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158b95 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158898 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:33:29.217152 [ 3815 ] {8e791ab3-0892-4cfb-92b3-95a02b60aa42} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50918) (comment: 02552_siphash128_reference.sql) (query 130, line 204) (in query: select sipHash128ReferenceKeyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4a2e 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158b95 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158898 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:33:29.221193 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000017fc4a2e 6. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158b95 7. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb207e 8. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018158898 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:33:29.520672 [ 46286 ] {72e249a5-97a0-4093-8f08-f3d9612839f8} executeQuery: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53152) (comment: 01089_alter_settings_old_format.sql) (query 4, line 12) (in query: ALTER TABLE old_format_mt MODIFY SETTING enable_mixed_granularity_parts = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3648: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd591d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:29.579114 [ 46286 ] {} TCPHandler: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3648: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd591d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:30.886382 [ 6024 ] {d035c356-f12f-4c05-ba75-7d77c96700f0} executeQuery: Code: 277. DB::Exception: Primary key (v) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50590) (comment: 02462_match_regexp_pk.sql) (query 9, line 10) (in query: SELECT count() FROM mt_match_pk WHERE match(v, '^a$|^b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003044b18f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: 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) @ 0x00000000321ae2ba 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:33:30.899091 [ 6024 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (v) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003044b18f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: 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) @ 0x00000000321ae2ba 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321adbbe 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321ad84e 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x00000000322cf437 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228a3fa 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:33:32.561622 [ 34277 ] {a1a93401-e4b5-47b9-800c-6557991496ea} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 617, line 206) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:32.579322 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:32.945264 [ 34260 ] {dbe8c494-06d5-4d50-8d33-9615805457d9} 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 hasAny([1], ['a']). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50518) (comment: 00555_hasAll_hasAny.sql) (query 37, line 42) (in query: select hasAny([1], ['a']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:32.951071 [ 34260 ] {} 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 hasAny([1], ['a']). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:33.007166 [ 34260 ] {5773521a-9b2a-49cd-8438-5cce7cc13144} 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 hasAll([1], ['a']). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50518) (comment: 00555_hasAll_hasAny.sql) (query 38, line 43) (in query: select hasAll([1], ['a']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:33.109060 [ 34260 ] {} 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 hasAll([1], ['a']). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:33.291668 [ 34260 ] {65e7170a-fab7-489a-b218-b25dfb801ec5} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), String because some of them are Array and some of them are not: In scope SELECT hasAll([[1, 2], [3, 4]], ['a', 'c']). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50518) (comment: 00555_hasAll_hasAny.sql) (query 39, line 44) (in query: select hasAll([[1, 2], [3, 4]], ['a', 'c']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52438b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:33.296320 [ 34260 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), String because some of them are Array and some of them are not: In scope SELECT hasAll([[1, 2], [3, 4]], ['a', 'c']). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52438b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:33.334218 [ 34260 ] {0e225c4e-76f8-4db1-b760-592a88ee69fb} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), String because some of them are Array and some of them are not: In scope SELECT hasAny([[1, 2], [3, 4]], ['a', 'c']). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50518) (comment: 00555_hasAll_hasAny.sql) (query 40, line 45) (in query: select hasAny([[1, 2], [3, 4]], ['a', 'c']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52438b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:33.339690 [ 34260 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), String because some of them are Array and some of them are not: In scope SELECT hasAny([[1, 2], [3, 4]], ['a', 'c']). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c52438b 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c5226cb 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002333c8d9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:33:35.558308 [ 34277 ] {1cf47e01-88a8-44bb-8d2d-0a8a235482e1} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 626, line 209) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:35.566631 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:35.717457 [ 6966 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:33:43: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:35.786213 [ 5476 ] {23c73632-8e2c-48e7-b938-5ebe4cdbba38} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 1, line 1) (in query: -- MIN, MAX AND FAMILY should check for errors in its input SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000025c3da15 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:35.804316 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000025c3da15 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:35.870859 [ 5476 ] {2d0f651c-23fc-4612-8ba7-d5dd7c1d1f6b} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 2, line 3) (in query: SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000025c3da15 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:35.884304 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000025c3da15 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.164446 [ 5476 ] {5629eef9-1ac8-40de-afaf-7294e04a9ef8} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 4, line 9) (in query: -- aggThrow should check for errors in its input SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/IO/ReadBuffer.cpp:55: DB::ReadBuffer::throwReadAfterEOF() @ 0x0000000023b29a6e 6. ./src/IO/ReadBuffer.h:165: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027e816cd 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.183852 [ 5476 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/IO/ReadBuffer.cpp:55: DB::ReadBuffer::throwReadAfterEOF() @ 0x0000000023b29a6e 6. ./src/IO/ReadBuffer.h:165: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027e816cd 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.293379 [ 5476 ] {e3794bb7-ef43-4fad-9d81-1abe1ecb5d78} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 5, line 12) (in query: -- categoricalInformationValue should check for errors in its input SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:36.302794 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:36.404555 [ 5476 ] {90b0731d-a25b-4813-a5c9-88012c5e4e56} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 6, line 15) (in query: SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.408228 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.487001 [ 5476 ] {1870489b-b0fa-427a-9b70-dd52705641a7} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 7, line 18) (in query: -- groupArray should check for errors in its input SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:425: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002469ac66 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000246f588c 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:33:36.494414 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:425: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002469ac66 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000246f588c 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:33:36.606860 [ 5476 ] {78982cec-cf60-4d6d-ba1c-ec57b7e57516} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 8, line 20) (in query: SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:337: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000246b9479 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.610324 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:337: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000246b9479 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.767476 [ 5476 ] {c76f1f6a-3f46-4191-880b-a98b9c9d209d} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 9, line 22) (in query: -- Same for groupArrayMovingXXXX SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027cf92c0 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.771408 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027cf92c0 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.864636 [ 5476 ] {d3634e6e-506f-42d9-b7d0-ddf1aa5864ff} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 10, line 24) (in query: SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027dd0520 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.868481 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027dd0520 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:36.898690 [ 5476 ] {d2796467-30b6-401e-a13e-1b2e5017a129} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 11, line 26) (in query: -- Histogram SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:36.902944 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:37.104951 [ 5476 ] {2541b95a-08f2-467d-8210-b43b2d89b493} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 12, line 30) (in query: -- StatisticalSample SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/AggregateFunctions/StatCommon.h:116: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027e8aecb 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:37.112160 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/AggregateFunctions/StatCommon.h:116: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027e8aecb 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:37.308517 [ 5476 ] {77822a6e-74d4-41a8-b657-0dbbe9c389b1} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 13, line 34) (in query: -- maxIntersections SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:153: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027b9085f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:37.321284 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:153: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027b9085f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:37.402517 [ 5476 ] {0effc94c-e336-4809-b2fc-6469d87a4ab7} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 14, line 38) (in query: -- sequenceNextNode (This was fine because it would fail in the next readBinary call, but better to add a test) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(''forward'', ''head''), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027eaaae6 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027eb3c8c 8. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 11. 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&) @ 0x000000002ad7a243 12. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, 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) @ 0x000000002b001523 14. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 2025.07.13 02:33:37.406541 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027eaaae6 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027eb3c8c 8. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 11. 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&) @ 0x000000002ad7a243 12. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, 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) @ 0x000000002b001523 14. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 2025.07.13 02:33:37.530864 [ 5476 ] {97e14cae-e1f9-4f28-810e-03cc7f30eb57} executeQuery: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 15, line 43) (in query: -- Fuzzer (ALL) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:101: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027eaae0b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027eb3c8c 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:33:37.544360 [ 5476 ] {} TCPHandler: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:101: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027eaae0b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027eb3c8c 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:33:37.599973 [ 5476 ] {1d123cb4-7b44-4e6f-bfb2-997a505f41d6} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 16, line 48) (in query: -- Fuzzer 2 (UBSAN) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027eaaae6 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027eb3c8c 8. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 11. 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&) @ 0x000000002ad7a243 12. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, 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) @ 0x000000002b001523 14. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 2025.07.13 02:33:37.606003 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000027eaaae6 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000027eb3c8c 8. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002845ddf8 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 11. 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&) @ 0x000000002ad7a243 12. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, 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) @ 0x000000002b001523 14. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 2025.07.13 02:33:37.655536 [ 5476 ] {200556c6-17a0-4c38-8381-10c3464d05a3} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 17, line 53) (in query: -- uniqUpTo SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:37.671697 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:37.740153 [ 5476 ] {9cc4a035-4b35-4c47-9994-1eb257c03626} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 18, line 57) (in query: -- quantiles SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:37.844011 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 2025.07.13 02:33:38.012043 [ 5476 ] {1141c707-1aeb-4e9f-9374-6e53df910e52} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53344) (comment: 02477_invalid_reads.sql) (query 19, line 60) (in query: SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/AggregateFunctions/QuantileTDigest.h:319: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x00000000255a1703 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:38.016790 [ 5476 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb302f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b29973 6. ./src/AggregateFunctions/QuantileTDigest.h:319: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x00000000255a1703 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54334d 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad7a243 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad789fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b001523 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 2025.07.13 02:33:38.952500 [ 46285 ] {5fdceb7b-0983-4d75-a99a-d1ca7b961060} executeQuery: Code: 36. DB::Exception: Negative positional argument number -9223372036854775808 is out of bounds. Expected in range [-1, -1]. In scope SELECT 1 GROUP BY -9223372036854775808. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60808) (comment: 03157_negative_positional_arguments_ubsan.sql) (query 1, line 1) (in query: SELECT 1 GROUP BY -9223372036854775808;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&&, String&&) @ 0x000000002cc63c8f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:845: DB::QueryAnalyzer::replaceNodesWithPositionalArguments(std::shared_ptr&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc235b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4225: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc5485d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05415 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:38.963551 [ 46285 ] {} TCPHandler: Code: 36. DB::Exception: Negative positional argument number -9223372036854775808 is out of bounds. Expected in range [-1, -1]. In scope SELECT 1 GROUP BY -9223372036854775808. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&&, String&&) @ 0x000000002cc63c8f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:845: DB::QueryAnalyzer::replaceNodesWithPositionalArguments(std::shared_ptr&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc235b2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4225: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc5485d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05415 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:39.754712 [ 5380 ] {260c590c-45bc-4cfc-803b-05453b0a7375} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60860) (comment: 02703_explain_query_tree_is_forbidden_with_old_analyzer.sql) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:39.782194 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:39.816295 [ 5476 ] {c1541365-0c47-47a3-ba9d-6f72f2341fcc} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60842) (comment: 01419_merge_tree_settings_sanity_check.sql) (query 2, line 3) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 100, index_granularity = 35052, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 173273807, compact_parts_max_bytes_to_buffer = 24588673, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10517157, merge_max_block_size = 4032, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 21036189, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 21072, primary_key_compress_block_size = 63406, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:489: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa468d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: 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) @ 0x0000000030c7a6fc 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:39.843766 [ 5476 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:489: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa468d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: 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) @ 0x0000000030c7a6fc 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.168919 [ 5476 ] {f0501d92-0d15-4f28-a432-2802a063bc89} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60842) (comment: 01419_merge_tree_settings_sanity_check.sql) (query 3, line 14) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_lower_max_size_of_merge = 100, index_granularity = 35052, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 173273807, compact_parts_max_bytes_to_buffer = 24588673, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10517157, merge_max_block_size = 4032, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 21036189, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 21072, primary_key_compress_block_size = 63406, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:501: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa4715 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: 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) @ 0x0000000030c7a6fc 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.172983 [ 5476 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:501: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa4715 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: 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) @ 0x0000000030c7a6fc 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.182180 [ 34277 ] {d8bdfacb-b70f-444a-8100-180c0ea14ce5} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 641, line 214) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.186854 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.391802 [ 5476 ] {f24e7cdb-381b-47bb-99a1-c427d16ab580} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60842) (comment: 01419_merge_tree_settings_sanity_check.sql) (query 4, line 25) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_optimize_entire_partition = 100, index_granularity = 35052, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 173273807, compact_parts_max_bytes_to_buffer = 24588673, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10517157, merge_max_block_size = 4032, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 21036189, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 21072, primary_key_compress_block_size = 63406, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:513: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa479f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: 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) @ 0x0000000030c7a6fc 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.397494 [ 5476 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:513: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa479f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: 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) @ 0x0000000030c7a6fc 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311d0043 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.765602 [ 5476 ] {ec0938b8-ff7c-46f3-972d-d0bacac23ec5} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60842) (comment: 01419_merge_tree_settings_sanity_check.sql) (query 6, line 46) (in query: ALTER TABLE mytable_local MODIFY SETTING number_of_free_entries_in_pool_to_execute_mutation = 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:489: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa468d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4064: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x0000000030ce071c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:401: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311d7261 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.785943 [ 5476 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdcfef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:489: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030fa468d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4064: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x0000000030ce071c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:401: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311d7261 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c991 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:40.882815 [ 5732 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:41.001565 [ 5380 ] {a871cd88-597a-4a66-afdf-59b2b5f54487} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47234) (comment: 02267_insert_empty_data.sql) (in query: DROP DATABASE IF EXISTS test_spftg4rf SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:33:41.004138 [ 5380 ] {a871cd88-597a-4a66-afdf-59b2b5f54487} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:42.424227 [ 5380 ] {594ef0cf-92ea-422d-938e-c10dfbca1f82} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=860). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60938) (comment: 01737_move_order_key_to_prewhere_select_final.sql) (query 6, line 9) (in query: select 'optimize_move_to_prewhere_if_final = 1';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:42.444288 [ 5380 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=860). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:42.958311 [ 57044 ] {969934f2-ce6e-48a4-9e1c-8d674230876c} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60978) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 1, line 1) (in query: SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:33:42.964627 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:33:43.038591 [ 57044 ] {2d6d9224-d7e6-436a-a7b8-d93a9356c18e} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60978) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 2, line 2) (in query: SELECT '-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:33:43.136573 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002c4c6537 5. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002c4c29cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002c56748c 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b2333cc 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b21d21f 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b012e8e 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04e49e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04d303 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 2025.07.13 02:33:43.319073 [ 32979 ] {0c43e1be-ce45-4b6d-a9f2-51a217b1ede1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34478) (comment: 01018_ddl_dictionaries_special.sql) (query 31, line 104) (in query: DROP DATABASE IF EXISTS test_11), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:43.325666 [ 32979 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:43.828130 [ 57044 ] {9c1db059-8380-43e7-b521-5d4e4009c8b2} executeQuery: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-9' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60978) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 8, line 8) (in query: SELECT '1E-9' AS x, toDecimal32(x, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:43.841417 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-9' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:43.907594 [ 57044 ] {144d1040-c599-488b-9e00-2d2e2cc8bf8d} executeQuery: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-10' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60978) (comment: 01425_decimal_parse_big_negative_exponent.sql) (query 9, line 9) (in query: SELECT '1E-10' AS x, toDecimal32(x, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:43.941430 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-10' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c412fb6 6. ./src/DataTypes/DataTypesDecimal.h:39: std::__shared_ptr_emplace>, std::allocator>>>::__shared_ptr_emplace[abi:ne190107]>>, 0>(std::allocator>>, unsigned long const&, unsigned long&) @ 0x000000002c4c524b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr>> std::allocate_shared[abi:ne190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x000000002c4c5046 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x000000002c4c20a8 9. ./src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b04d018 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b04cce7 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:45.143566 [ 34277 ] {2df5b99b-d031-4cd1-8508-96ba85e3f714} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 665, line 222) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:45.171073 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:45.282596 [ 6126 ] {4c550c75-c100-4cc8-90f6-43e9af62efb8} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32816) (comment: 01440_big_int_least_greatest.sql) (query 7, line 33) (in query: SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c0b3071 6. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001bdcac29 7. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001bdc92ea 8. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:33:45.297270 [ 6126 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c0b3071 6. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001bdcac29 7. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001bdc92ea 8. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:33:45.383230 [ 29256 ] {1b4643a2-db3b-4c5a-967f-02c661cebc7b} 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.3.20372.altinityantalya (altinity build)) (from [::1]:32846) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6b82d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:33:45.391808 [ 29256 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6c68f 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad6b82d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:33:45.494600 [ 6126 ] {4057366b-1710-45e3-8586-6381bf874ade} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:32816) (comment: 01440_big_int_least_greatest.sql) (query 8, line 34) (in query: SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001d019651 6. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd32249 7. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd30a4a 8. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:33:45.498464 [ 6126 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001d019651 6. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd32249 7. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd30a4a 8. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:33:45.548810 [ 34340 ] {877a4ea0-b04b-49e7-8c1b-77251712eeea} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47356) (comment: 01630_simple_aggregate_function_in_summing_merge_tree.sql) (in query: DROP DATABASE IF EXISTS test_eci3xtnq SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:33:45.569896 [ 34340 ] {877a4ea0-b04b-49e7-8c1b-77251712eeea} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:45.700048 [ 57041 ] {6b6d8f50-c963-4f9f-809b-9d0318459b85} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47380) (comment: 01630_simple_aggregate_function_in_summing_merge_tree.sql) (in query: DROP DATABASE IF EXISTS test_eci3xtnq SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:33:45.705110 [ 57041 ] {6b6d8f50-c963-4f9f-809b-9d0318459b85} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:45.945590 [ 7216 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:34:17: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:46.022449 [ 34277 ] {ae1d0ded-302e-481e-b1f1-ae496e2563fc} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 671, line 224) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:46.034776 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:48.081630 [ 5380 ] {8cc6f8a8-13f9-403c-9ad5-da18be465566} executeQuery: Code: 57. DB::Exception: Table test_7.t_map_lc already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60992) (comment: 03156_tuple_map_low_cardinality.sql) (query 9, line 19) (in query: CREATE TABLE t_map_lc (`id` UInt64, `t` Tuple(m Map(LowCardinality(String), LowCardinality(String)))) ENGINE = MergeTree ORDER BY id SETTINGS min_bytes_for_wide_part = '10G', index_granularity = 2947, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 65, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 97071632, compact_parts_max_granules_to_buffer = 178, compact_parts_merge_max_bytes_to_prefetch_part = 31543287, merge_max_block_size = 12458, old_parts_lifetime = 95., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 237428, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3781149810, index_granularity_bytes = 23037790, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 68, 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 = 85778, primary_key_compress_block_size = 60747, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:48.107452 [ 5380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t_map_lc already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:49.466555 [ 46286 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:50.015322 [ 46286 ] {d44e809b-9934-43b9-adc4-3db23f3edd6c} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3EdgeLengthM is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3EdgeLengthM(100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51514) (comment: 01074_h3_range_check.sql) (query 1, line 3) (in query: SELECT h3EdgeLengthM(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000001afa6faf 5. DB::(anonymous namespace)::FunctionH3EdgeLengthM::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c14742e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:50.027198 [ 46286 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3EdgeLengthM is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3EdgeLengthM(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000001afa6faf 5. DB::(anonymous namespace)::FunctionH3EdgeLengthM::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c14742e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:50.174065 [ 46286 ] {8831ef24-8a56-44e4-9cf7-204d2fac8512} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaM2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaM2(100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51514) (comment: 01074_h3_range_check.sql) (query 2, line 4) (in query: SELECT h3HexAreaM2(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000001afa6faf 5. DB::(anonymous namespace)::FunctionH3HexAreaM2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c16244e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:50.186827 [ 46286 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaM2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaM2(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000001afa6faf 5. DB::(anonymous namespace)::FunctionH3HexAreaM2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c16244e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:50.431379 [ 46286 ] {5165d631-0e33-4629-9f49-e986bc01fc85} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaKm2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaKm2(100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51514) (comment: 01074_h3_range_check.sql) (query 3, line 5) (in query: SELECT h3HexAreaKm2(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000001afa6faf 5. DB::(anonymous namespace)::FunctionH3HexAreaKm2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c160bec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:50.433752 [ 34260 ] {c9ae0050-a50c-42f2-8146-e4a77b58ab10} executeQuery: Code: 57. DB::Exception: Table test_70lhrkys.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03290_nullable_json.gen.sql) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_70lhrkys.test UUID '0ec59fb8-d932-43ff-a6ab-cb184d4b9dad' (`json` Nullable(JSON(a UInt32, b Array(UInt32), c Nullable(UInt32), d Tuple(e UInt32, f Nullable(UInt32))))) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 42623, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 124, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 138834874, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 4114843, merge_max_block_size = 7482, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 912657, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2565327658, index_granularity_bytes = 17966939, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 20559, primary_key_compress_block_size = 15208, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:50.436118 [ 46286 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3HexAreaKm2 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3HexAreaKm2(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000001afa6faf 5. DB::(anonymous namespace)::FunctionH3HexAreaKm2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c160bec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:33:50.565885 [ 34260 ] {c9ae0050-a50c-42f2-8146-e4a77b58ab10} executeQuery: Code: 57. DB::Exception: Table test_70lhrkys.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33056) (comment: 03290_nullable_json.gen.sql) (query 18, line 25) (in query: CREATE TABLE test (`json` Nullable(JSON(a UInt32, b Array(UInt32), c Nullable(UInt32), d Tuple(e UInt32, f Nullable(UInt32))))) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 42623, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 124, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 138834874, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 4114843, merge_max_block_size = 7482, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 912657, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2565327658, index_granularity_bytes = 17966939, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 20559, primary_key_compress_block_size = 15208, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:50.581379 [ 34260 ] {} TCPHandler: Code: 57. DB::Exception: Table test_70lhrkys.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:33:50.817301 [ 34277 ] {ddafe11b-3217-4323-b2d3-898d55348f94} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 695, line 232) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:50.861530 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:51.268946 [ 34277 ] {a07f9cd5-8957-42b0-a1ba-3d3866434cdb} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 698, line 233) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:51.277504 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:51.816294 [ 3188 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d604150 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d6048e1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:33:53.067011 [ 5105 ] {05dab92e-2ca4-404c-9807-076d0b2535fe} executeQuery: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 20, line 26) (in query: CREATE TABLE clone_as_foo_memory CLONE AS foo_memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc702a0 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:53.078998 [ 5105 ] {} TCPHandler: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc702a0 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:53.645244 [ 5105 ] {d2b9a3ad-2c6d-4e2a-a081-06068bfed11b} executeQuery: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 24, line 33) (in query: CREATE TABLE clone_as_foo_file CLONE AS foo_file;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc702a0 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:53.655279 [ 5105 ] {} TCPHandler: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc702a0 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:54.659433 [ 34277 ] {3e7a39a4-f7b7-4a15-a628-aee57addd773} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 713, line 238) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:54.665570 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:55.904225 [ 5105 ] {f66008d5-d474-4f83-858e-97d402521aaa} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 38, line 52) (in query: CREATE TABLE clone_as_foo_merge_tree_p_y CLONE AS foo_merge_tree ENGINE=MergeTree PRIMARY KEY y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc701e3 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:55.909162 [ 5105 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc701e3 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:58.025871 [ 5105 ] {163074ce-6b20-4164-b581-dad2421884fe} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 52, line 71) (in query: CREATE TABLE clone_as_foo_replacing_merge_tree_p_y CLONE AS foo_replacing_merge_tree ENGINE=ReplacingMergeTree PRIMARY KEY y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc701e3 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:58.036129 [ 5105 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc701e3 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:58.269558 [ 34277 ] {b6a9e995-97fe-4c42-9068-1efd229773c6} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 734, line 245) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:58.276383 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:58.675119 [ 34277 ] {c0cb11f2-e55b-4c47-a77b-a4cd4bf572f4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 737, line 246) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:58.683191 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:33:59.717996 [ 5732 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:33:59.720154 [ 5732 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:33:59.768140 [ 5105 ] {986ca235-0c40-4227-8577-6aeb2614b95e} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/test_7/test_foo_replicated_merge_tree/replicas/r1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 58, line 80) (in query: CREATE TABLE clone_as_foo_replicated_merge_tree CLONE AS foo_replicated_merge_tree;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000305ba5f9 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x000000003059c684 7. ./build_docker/./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&) @ 0x0000000030597480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:33:59.779726 [ 5105 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/test_7/test_foo_replicated_merge_tree/replicas/r1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000305ba5f9 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x000000003059c684 7. ./build_docker/./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&) @ 0x0000000030597480 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:00.134000 [ 6126 ] {adecd3a0-dbe6-42ce-ae88-1c026bb9cfe7} executeQuery: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35594) (comment: 01459_default_value_of_argument_type_nullptr_dereference.sql) (query 1, line 1) (in query: SELECT defaultValueOfTypeName(FQDN());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a064c40 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:00.137899 [ 6126 ] {} TCPHandler: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(FQDN()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionDefaultValueOfTypeName::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a064c40 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf518 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.015686 [ 34277 ] {89a86083-f4a4-4073-9271-0751f656557f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 752, line 251) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.021691 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.286327 [ 5732 ] {7993679f-0b1f-483d-ad33-bace10067837} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35618) (comment: 02731_zero_objects_in_metadata.sh) (query 2, line 3) (in query: CREATE TABLE test (`id` Int32, `empty` Array(Int32)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 0, min_bytes_for_wide_part = 0, disk = 's3_cache', index_granularity = 19441, ratio_of_defaults_for_sparse_serialization = 0.07309917360544205, replace_long_file_name_to_hash = false, max_file_name_length = 120, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 179313194, compact_parts_max_granules_to_buffer = 223, compact_parts_merge_max_bytes_to_prefetch_part = 33013556, merge_max_block_size = 5578, old_parts_lifetime = 274., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 290101, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9542497705, index_granularity_bytes = 7696061, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, 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 = false, marks_compress_block_size = 65780, primary_key_compress_block_size = 56825, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.383262 [ 5732 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.427297 [ 5105 ] {b8b2b9b1-9e1f-4098-bc20-44f965b16ed7} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 63, line 87) (in query: CREATE TABLE clone_as_foo_replicated_merge_tree_p_y CLONE AS foo_replicated_merge_tree ENGINE=ReplicatedMergeTree('/clickhouse/tables/{database}/clone_as_foo_replicated_merge_tree_p_y', 'r1') PRIMARY KEY y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc701e3 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.439772 [ 5105 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc701e3 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.752232 [ 36554 ] {fa3cfeb1-5793-4480-91f6-cb59608c361f} BackupsWorker: Failed to make backup Disk('backups', 'test_s3_backup'): Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:533: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002bf79c62 6. ./build_docker/./src/Backups/BackupImpl.cpp:177: DB::BackupImpl::open() @ 0x000000002bf76a72 7. ./build_docker/./src/Backups/BackupImpl.cpp:133: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr) @ 0x000000002bf77fb9 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072d0a 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:182: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c07186b 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 11. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002bf48d96 12. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5eb88 13. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56be3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 15. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf479f3 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476eb 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:01.757354 [ 32979 ] {fa3cfeb1-5793-4480-91f6-cb59608c361f} executeQuery: Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35632) (comment: 02731_zero_objects_in_metadata.sh) (query 1, line 2) (in query: BACKUP TABLE test TO Disk('backups', 'test_s3_backup');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:533: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002bf79c62 6. ./build_docker/./src/Backups/BackupImpl.cpp:177: DB::BackupImpl::open() @ 0x000000002bf76a72 7. ./build_docker/./src/Backups/BackupImpl.cpp:133: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr) @ 0x000000002bf77fb9 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072d0a 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:182: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c07186b 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 11. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002bf48d96 12. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5eb88 13. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56be3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 15. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:01.777837 [ 32979 ] {} TCPHandler: Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:533: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002bf79c62 6. ./build_docker/./src/Backups/BackupImpl.cpp:177: DB::BackupImpl::open() @ 0x000000002bf76a72 7. ./build_docker/./src/Backups/BackupImpl.cpp:133: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr) @ 0x000000002bf77fb9 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c072d0a 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:182: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c07186b 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06ffad 11. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002bf48d96 12. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5eb88 13. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56be3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 15. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf479f3 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476eb 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:02.976451 [ 5732 ] {e19c0585-55e6-4c53-9654-ebe80dbc50ff} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 811.46 KiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35662) (comment: 02353_simdjson_buffer_overflow.sql) (query 4, line 7) (in query: SELECT count() FROM system.numbers_mt WHERE NOT ignore(JSONExtract('{' || repeat('"a":"b",', rand() % 10) || '"c":"d"}', 'a', 'String')) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:02.987872 [ 5732 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 811.46 KiB (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:03.004689 [ 3465 ] {0c094833-96f0-4784-86a3-18b4f7f3d256::0_1_9_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c5a377 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3bbd14 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c260b8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:03.005090 [ 3458 ] {0c094833-96f0-4784-86a3-18b4f7f3d256::1_4_14_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:04.048191 [ 32979 ] {c42de336-b801-4794-9e61-80b19d2a2144} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35670) (comment: 03315_join_on_optimize_pass_alias.sql) (query 8, line 12) (in query: SELECT e2 FROM t1 FULL OUTER JOIN t2 ON ( (((t1.y = t2.y) OR ((t1.y IS NULL) AND (t2.y IS NULL))) AND (COALESCE(t1.x, 0) != 2)) OR (((t1.x = t2.x)) AND ((t2.x IS NOT NULL) AND (t1.x IS NOT NULL))) AS e2 ) ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:04.076793 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffcdd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:04.397108 [ 5115 ] {} test_50qnodpd.test_move_partition_src (0c094833-96f0-4784-86a3-18b4f7f3d256): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:34:04.404474 [ 5115 ] {} DatabaseCatalog: Cannot drop table test_50qnodpd.test_move_partition_src (0c094833-96f0-4784-86a3-18b4f7f3d256). Will retry later.: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:05.025524 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:06.197525 [ 5105 ] {ddba95bf-58cb-4ddd-89f7-9305a2a5782b} executeQuery: Code: 344. DB::Exception: CREATE CLONE AS is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51612) (comment: 03231_create_with_clone_as.sql) (query 88, line 117) (in query: CREATE TABLE clone_as_foo_merge_tree CLONE AS foo_merge_tree;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1712: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7f047 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:34:06.201100 [ 5105 ] {} TCPHandler: Code: 344. DB::Exception: CREATE CLONE AS is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1712: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7f047 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.384218 [ 3863 ] {374824da-8332-4b92-bfab-7ed4e9d6fa32} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:32876) (comment: 01710_projections_in_distributed_query.sql) (query 6, line 13) (in query: SELECT toStartOfMinute(`__table1`.`dt`) AS `dt_m`, sum(`__table1`.`cost`) AS `sum(cost)` FROM `test_11`.`projection_test` AS `__table1` GROUP BY toStartOfMinute(`__table1`.`dt`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.384276 [ 5971 ] {a54cfd5e-232a-4255-af9d-112ea77e2612} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43356) (comment: 01710_projections_in_distributed_query.sql) (query 6, line 13) (in query: SELECT toStartOfMinute(`__table1`.`dt`) AS `dt_m`, sum(`__table1`.`cost`) AS `sum(cost)` FROM `test_11`.`projection_test` AS `__table1` GROUP BY toStartOfMinute(`__table1`.`dt`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.386295 [ 6249 ] {7000c4bf-0dab-4190-9f47-766567b2f7fa} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38348) (comment: 01710_projections_in_distributed_query.sql) (query 6, line 13) (in query: SELECT toStartOfMinute(`__table1`.`dt`) AS `dt_m`, sum(`__table1`.`cost`) AS `sum(cost)` FROM `test_11`.`projection_test` AS `__table1` GROUP BY toStartOfMinute(`__table1`.`dt`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.387734 [ 5971 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.388950 [ 3863 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.391356 [ 6249 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:08.408812 [ 5480 ] {cd28dba1-f2ad-4524-856f-6a3251cc43d8} executeQuery: Code: 584. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35836) (comment: 01710_projections_in_distributed_query.sql) (query 6, line 13) (in query: select toStartOfMinute(dt) dt_m, sum(cost) from projection_test group by dt_m;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:34:08.415408 [ 6249 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38348, local: [::ffff:127.0.0.9]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:08.417179 [ 6249 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38348, local: [::ffff:127.0.0.9]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:08.440833 [ 5480 ] {} TCPHandler: Code: 584. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.066068 [ 34277 ] {42d607c2-e95c-45a9-92a5-23efa93d3d10} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 791, line 264) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.083182 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.431032 [ 34277 ] {87df7e33-c63f-4e94-a83d-1ca0f1afc880} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 794, line 265) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.449448 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.569173 [ 6022 ] {7b79e705-3173-4f83-9731-e77855893bbc} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50346) (comment: 02497_storage_join_right_assert.sql) (query 7, line 10) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.584524 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:09.983254 [ 3450 ] {dd587ef1-4868-4d44-8eb2-6ff667f3a5b3::1_1_10_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030c0a277 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c26d91 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c26403 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:10.057094 [ 7216 ] {} test_50qnodpd.test_move_partition_dest (dd587ef1-4868-4d44-8eb2-6ff667f3a5b3): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:34:10.058850 [ 7216 ] {} DatabaseCatalog: Cannot drop table test_50qnodpd.test_move_partition_dest (dd587ef1-4868-4d44-8eb2-6ff667f3a5b3). Will retry later.: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:10.163310 [ 3816 ] {6878dd02-bdce-4703-987d-49f08650ee9d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37814) (comment: 03030_system_flush_distributed_settings.sql) (in query: DROP DATABASE IF EXISTS test_1t7rxj0p SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:10.165732 [ 3816 ] {6878dd02-bdce-4703-987d-49f08650ee9d} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:10.765737 [ 34277 ] {581eec1f-794f-48cc-9b73-bd306337918e} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 800, line 267) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:10.788895 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:11.504858 [ 5380 ] {ca57a0c0-3125-40ed-856d-97e28a2a95be} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50508) (comment: 03364_prewhere_parallel_replicas.sh) (query 1, line 2) (in query: CREATE TABLE t (`a` UInt32, `b` UInt32) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 56881, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 47, min_bytes_for_full_part_storage = 351868662, compact_parts_max_bytes_to_buffer = 195629483, compact_parts_max_granules_to_buffer = 78, compact_parts_merge_max_bytes_to_prefetch_part = 26029017, merge_max_block_size = 9713, old_parts_lifetime = 12., prefer_fetch_merged_part_size_threshold = 4817000105, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9038738512, index_granularity_bytes = 12819572, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 32, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 83846, primary_key_compress_block_size = 49297, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:11.540610 [ 5380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:11.863582 [ 34340 ] {test_11_prewhere_parallel_replicas_12504} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT * FROM t WHERE b < 100000. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50520) (comment: 03364_prewhere_parallel_replicas.sh) (query 1, line 1) (in query: SELECT * FROM t WHERE b < 100000), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:34:11.885068 [ 34340 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT * FROM t WHERE b < 100000. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:34:12.647873 [ 34277 ] {3cfb7bf6-3730-48d9-9cae-a09d67bb7df9} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 809, line 270) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:12.664494 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:14.008246 [ 5380 ] {cfdad216-d02a-485d-ab2e-85691e0177b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=855). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50618) (comment: 01446_json_strings_each_row.sh) (query 1, line 1) (in query: TRUNCATE TABLE test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:14.020941 [ 5380 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=855). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:14.450414 [ 5382 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:14.981410 [ 34277 ] {8bbb9598-f2ec-4d7c-a2cd-ef2f7652ff01} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 818, line 273) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:15.005308 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:15.684966 [ 46286 ] {cdfe742e-ce16-4c9c-9552-8497354b333c} test_7.mt_compact (b3f86f78-6be6-460d-a33e-4ba515086e94): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 10485760. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:34:15.962069 [ 46286 ] {e2bd4400-7cb6-4388-a923-b1790d0d5937} executeQuery: Code: 48. DB::Exception: Can't change settings. Reason: Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 1000, min_bytes_for_wide_part = 10485760. Parts with non-adaptive granularity can be stored only in Wide (default) format. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50722) (comment: 01055_compact_parts_1.sql) (query 2, line 3) (in query: alter table mt_compact modify setting min_rows_for_wide_part = 1000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3897: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6e2a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:15.966373 [ 46286 ] {} TCPHandler: Code: 48. DB::Exception: Can't change settings. Reason: Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 1000, min_bytes_for_wide_part = 10485760. Parts with non-adaptive granularity can be stored only in Wide (default) format. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce9fcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3897: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd6e2a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:16.800774 [ 46286 ] {fd6dd46f-7c59-4755-980c-abaa2686d1a5} executeQuery: Code: 36. DB::Exception: Cannot replace partition '1' because part '1_1_1_0' has inconsistent granularity with table. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50722) (comment: 01055_compact_parts_1.sql) (query 6, line 9) (in query: alter table mt_compact attach partition 1 from mt_compact_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000023e03bef 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2272: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003120dafb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e8ac 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:16.836368 [ 46286 ] {} TCPHandler: Code: 36. DB::Exception: Cannot replace partition '1' because part '1_1_1_0' has inconsistent granularity with table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000023e03bef 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2272: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003120dafb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e8ac 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.104256 [ 5480 ] {c908d351-3d39-4f44-b86e-b5576d3dc65d} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 26, line 38) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.112112 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.217079 [ 5480 ] {a4cf45ce-cefd-4c4f-b932-34bf2593331d} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 27, line 39) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 > 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.228427 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.370289 [ 46286 ] {6f2520fa-8a22-4893-a838-b12401696389} test_7.mt_compact (978a2d2a-86ad-4be8-9c56-cc17a02e4187): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 1000, min_bytes_for_wide_part = 10485760. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:34:17.632423 [ 5480 ] {7a68efa0-5783-4b6f-9d4c-e3c90361c1b6} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 29, line 42) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.637533 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.701196 [ 34277 ] {8fed97de-dbda-424d-89a7-5b9de9a07618} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 830, line 277) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.775031 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.785323 [ 5480 ] {7c1abfbd-a7da-4d43-a913-c9885f62645a} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 30, line 43) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.789575 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.932327 [ 5480 ] {913a2268-1e2e-4bad-b2d2-029dbcde3e1b} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 31, line 44) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON NULL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:17.940541 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.054436 [ 5480 ] {b803938a-0d44-4efd-81eb-076998fa3b3a} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 32, line 45) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 != 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.064194 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.183109 [ 5480 ] {8f2f5e59-fcf2-49bc-8a97-71c62c5575dd} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 33, line 47) (in query: -- Here is another error code because equality is handled differently in CollectJoinOnKeysVisitor. -- We can change the error code, but it will become inconsistent for other cases -- where we actually expect AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION/INCOMPATIBLE_TYPE_OF_JOIN. -- These checks are more reliable after switching to a new analyzer, they return INCOMPATIBLE_TYPE_OF_JOIN consistent with cases above SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.189360 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.312352 [ 5480 ] {ec7d6a31-e6f0-41da-86ab-6e3813e3f08a} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 34, line 52) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.344497 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000002de0080f 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff0d9 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.468120 [ 5480 ] {490c6986-3b31-4782-9c13-f34aedfe4cf1} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 35, line 54) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.475764 [ 5480 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.506447 [ 3815 ] {c5bf3bb7-4cca-4b52-bd1b-e0ec5eeccf2d} executeQuery: Code: 57. DB::Exception: Table test_7.foo already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50868) (comment: 01011_test_create_as_skip_indices.sql) (query 1, line 1) (in query: CREATE TABLE foo (`key` int, INDEX i1 key TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 4906, min_bytes_for_wide_part = 759257071, 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 = 472373430, compact_parts_max_bytes_to_buffer = 485452175, compact_parts_max_granules_to_buffer = 112, compact_parts_merge_max_bytes_to_prefetch_part = 27431572, merge_max_block_size = 3640, old_parts_lifetime = 82., prefer_fetch_merged_part_size_threshold = 6874062717, 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 = 13863724, 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 = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 83126, primary_key_compress_block_size = 12872, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.516596 [ 3815 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.foo already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.561969 [ 6933 ] {33029b83-3006-4e4b-8b61-8f8c170dc487} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (9000) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 0).). 2025.07.13 02:34:18.624733 [ 5480 ] {e1b908c7-01c5-4bf3-83ae-386f595f1cb3} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 36, line 55) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.631152 [ 5480 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.790898 [ 5480 ] {fca4170f-c396-4eb9-ad67-37bfd5e7024e} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 37, line 57) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key2, key3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.801808 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.867015 [ 34277 ] {bad492d7-8928-4b76-944c-50ed959535d3} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 836, line 279) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.888774 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.941821 [ 5480 ] {77002249-8367-47b1-880f-dfa66ec38a73} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 38, line 58) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:18.962336 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:19.113286 [ 5480 ] {e5d90ef9-22f8-42da-b63d-9e88e9ea7f8c} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 39, line 59) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:19.138653 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:19.328154 [ 5480 ] {90bd390f-386b-4fcc-ad1c-781e33b737a5} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 40, line 60) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003044b20f 5. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000030446e8e 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:19.345686 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003044b20f 5. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000030446e8e 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:19.465875 [ 5480 ] {d91ddc42-21a0-4b0e-8736-6fc2b9960d67} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50462) (comment: 02498_storage_join_key_positions.sql) (query 41, line 61) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.key3 AND t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:19.486063 [ 5480 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000304473df 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff1f0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:20.747239 [ 57039 ] {33797505-fcbe-4f29-a5ea-001404850ce3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=857). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50846) (comment: 00126_buffer.sql) (query 13, line 16) (in query: SELECT b, c FROM buffer_00126 ORDER BY a, b, c;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:20.779944 [ 57039 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=857). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:20.984593 [ 5732 ] {95e08cca-196e-4bbb-af55-0aa0b091b983} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52984) (comment: 00126_buffer.sql) (in query: DROP DATABASE IF EXISTS test_4ho1j2kv SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:20.989105 [ 5732 ] {95e08cca-196e-4bbb-af55-0aa0b091b983} DynamicQueryHandler: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.173292 [ 6909 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:34:26: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.178608 [ 6940 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:34:39: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.288859 [ 57044 ] {184a5f89-1a74-432e-90e0-45264901e34c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4cb53493-f3ef-4624-90fb-f9d2ff960889'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52988) (comment: 03283_json_binary_serialization_use_default_setttings.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nuse82ur ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:21.290410 [ 57044 ] {184a5f89-1a74-432e-90e0-45264901e34c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4cb53493-f3ef-4624-90fb-f9d2ff960889'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.462902 [ 57925 ] {f1677d6e-a72c-456c-9e0c-9112aef8d3c3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:64f4d154-59b9-4a36-8864-4cc21ab6e9c2'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53002) (comment: 02524_fuzz_and_fuss_2.sql) (in query: CREATE DATABASE IF NOT EXISTS test_yzcdnuv3 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:21.464239 [ 57925 ] {f1677d6e-a72c-456c-9e0c-9112aef8d3c3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:64f4d154-59b9-4a36-8864-4cc21ab6e9c2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.708784 [ 5732 ] {01ab5ce6-67ab-48dd-b8a8-a762805402f8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:0dac27bb-3ca0-472b-9a0a-f471e1caa4a1'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53010) (comment: 00344_row_number_in_all_blocks.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qw3rkqn5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:21.711598 [ 5732 ] {01ab5ce6-67ab-48dd-b8a8-a762805402f8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:0dac27bb-3ca0-472b-9a0a-f471e1caa4a1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.839908 [ 34277 ] {6eb72bc7-1292-4d9c-98b8-7056442f9fad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=851). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 849, line 283) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:34:21.850745 [ 34277 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=851). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:34:21.859985 [ 5105 ] {9f9e5e45-8081-4268-8747-0cc80b4966c8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:f15c08b5-3dff-4a41-8caa-2c81d11bfa48'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53024) (comment: 01164_detach_attach_partition_race.sh) (in query: CREATE DATABASE IF NOT EXISTS test_xqe7rxuc ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:21.870118 [ 5105 ] {9f9e5e45-8081-4268-8747-0cc80b4966c8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:f15c08b5-3dff-4a41-8caa-2c81d11bfa48'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:21.887121 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 0).). 2025.07.13 02:34:21.896054 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9000).). 2025.07.13 02:34:21.897415 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9001).). 2025.07.13 02:34:21.899119 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9002).). 2025.07.13 02:34:21.899819 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9003).). 2025.07.13 02:34:21.900541 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9004).). 2025.07.13 02:34:21.905458 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9005).). 2025.07.13 02:34:21.906161 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9006).). 2025.07.13 02:34:21.907150 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9007).). 2025.07.13 02:34:21.907861 [ 57042 ] {6e28e8de-d63f-4bb6-9ea8-7df68ba2ea11::19700101_19700101_1_3_2} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9008).). 2025.07.13 02:34:22.023559 [ 34273 ] {64870d28-f78a-49f7-996e-f9b4b3b8e020} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:8b4bbd95-8cf1-43ca-85d9-cecea4538729'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53070) (comment: 01644_distributed_async_insert_fsync_smoke.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0fgp616o ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.027278 [ 34273 ] {64870d28-f78a-49f7-996e-f9b4b3b8e020} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:8b4bbd95-8cf1-43ca-85d9-cecea4538729'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.119402 [ 5105 ] {a1e87605-8e6e-4f11-adeb-8a80c7d2f035} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:bf0c27c9-f30f-4e59-80be-670ec5819c45'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53086) (comment: 03008_s3_plain_rewritable_alter_partition.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ty7dv1qt ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.129617 [ 5105 ] {a1e87605-8e6e-4f11-adeb-8a80c7d2f035} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:bf0c27c9-f30f-4e59-80be-670ec5819c45'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.233243 [ 57044 ] {73044247-158a-4b67-b0d5-509546eae085} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:93543a5a-c39e-4b3b-ae36-a302c6a4c032'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53102) (comment: 01825_new_type_json_12.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5pkzsfsb ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.236750 [ 57044 ] {73044247-158a-4b67-b0d5-509546eae085} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:93543a5a-c39e-4b3b-ae36-a302c6a4c032'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.357370 [ 57044 ] {e548a6b3-b79f-4262-b512-2f3da1c1c92a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:584df89b-7ce9-4aa0-b090-55ec8b4060d7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53120) (comment: 02564_query_id_header.sh) (in query: CREATE DATABASE IF NOT EXISTS test_m7t5pmhi ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.384006 [ 57044 ] {e548a6b3-b79f-4262-b512-2f3da1c1c92a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:584df89b-7ce9-4aa0-b090-55ec8b4060d7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.482656 [ 5971 ] {69f890ab-0bec-42ba-8a24-b69768f44fce} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:943d6d74-d1c0-476d-b149-c50b10496794'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53132) (comment: 03235_groupArray_string_consistency.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lp0zrc12 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.487737 [ 5971 ] {69f890ab-0bec-42ba-8a24-b69768f44fce} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:943d6d74-d1c0-476d-b149-c50b10496794'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.552110 [ 57044 ] {7d1efb54-4a91-4205-9b3b-8a73001b5f33} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:ac5d1cbc-75c9-4ce2-ada0-290f4b324a58'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53142) (comment: 01732_alters_bad_conversions.sql) (in query: CREATE DATABASE IF NOT EXISTS test_t707dwde ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.553651 [ 57044 ] {7d1efb54-4a91-4205-9b3b-8a73001b5f33} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:ac5d1cbc-75c9-4ce2-ada0-290f4b324a58'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.670344 [ 57925 ] {f4d1ccd0-2cf2-4c9c-915b-ed8b0464ef33} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:f0aac069-410a-4bc5-982c-e1dd8d499386'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53156) (comment: 02184_ipv6_select_parsing.sql) (in query: CREATE DATABASE IF NOT EXISTS test_uoyd9xxf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.675989 [ 57925 ] {f4d1ccd0-2cf2-4c9c-915b-ed8b0464ef33} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:f0aac069-410a-4bc5-982c-e1dd8d499386'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.806497 [ 3863 ] {229ba8f8-e8cd-4c34-9873-7cf8dfdf66c4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:c7b492d0-2804-4afb-9494-a65dfe26f518'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53164) (comment: 03233_async_insert_infile_format.sh) (in query: CREATE DATABASE IF NOT EXISTS test_6q6ww3gs ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.814247 [ 3863 ] {229ba8f8-e8cd-4c34-9873-7cf8dfdf66c4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:c7b492d0-2804-4afb-9494-a65dfe26f518'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:22.953489 [ 57925 ] {e0c626dc-3cb1-432e-80f0-5dffdc7b60e3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:ceeb35b5-d3bc-498d-a0ad-168f0e6993fc'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53172) (comment: 01455_nullable_type_with_if_agg_combinator.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3onrropy ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:22.958573 [ 57925 ] {e0c626dc-3cb1-432e-80f0-5dffdc7b60e3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:ceeb35b5-d3bc-498d-a0ad-168f0e6993fc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.070104 [ 57044 ] {435790a4-6cba-4244-8d3f-52e96053b339} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:6e84d23b-20b7-4981-bd64-02d6d5feaab7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53188) (comment: 02579_parameterized_replace.sql) (in query: CREATE DATABASE IF NOT EXISTS test_85hfbwtu ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.078733 [ 57044 ] {435790a4-6cba-4244-8d3f-52e96053b339} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:6e84d23b-20b7-4981-bd64-02d6d5feaab7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.270684 [ 3816 ] {1b5df8cd-38fc-461c-adc5-356fcb7ab338} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:489711b0-7eb6-4d3e-bb0a-656505a042fd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53192) (comment: 02576_predicate_push_down_sorting_fix.sql) (in query: CREATE DATABASE IF NOT EXISTS test_de2gw0u6 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.273663 [ 3816 ] {1b5df8cd-38fc-461c-adc5-356fcb7ab338} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:489711b0-7eb6-4d3e-bb0a-656505a042fd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.444162 [ 3816 ] {1a6dcec4-0baf-4684-9af1-9ea3b7f964d7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:9affcc3d-5113-4b8d-9f69-202ac1022830'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53204) (comment: 02590_interserver_mode_client_info_initial_query_start_time.sh) (in query: CREATE DATABASE IF NOT EXISTS test_zcxzjasp ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.460820 [ 3816 ] {1a6dcec4-0baf-4684-9af1-9ea3b7f964d7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:9affcc3d-5113-4b8d-9f69-202ac1022830'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.594399 [ 57925 ] {50cb1973-092d-4e17-8ce8-3977c514a632} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:af089683-dd3a-4385-8118-d515de0b7c74'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53222) (comment: 02676_analyzer_limit_offset.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0pa8bzvy ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.600900 [ 57925 ] {50cb1973-092d-4e17-8ce8-3977c514a632} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:af089683-dd3a-4385-8118-d515de0b7c74'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.657111 [ 3816 ] {e68be155-6780-4f44-bb54-a2504799e944} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:2c371fa3-b521-4564-a67b-72b60f6f8225'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53228) (comment: 02362_part_log_merge_algorithm.sql) (in query: CREATE DATABASE IF NOT EXISTS test_h1nylpzb ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.659412 [ 3816 ] {e68be155-6780-4f44-bb54-a2504799e944} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:2c371fa3-b521-4564-a67b-72b60f6f8225'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.763017 [ 3863 ] {045a0f12-afbc-4a94-9c34-8bd7c75b0845} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:793a6643-1712-489a-9b04-5b5f023f8e37'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53238) (comment: 01378_alter_rename_with_ttl_zookeeper.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1n7jioh0 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.783705 [ 3863 ] {045a0f12-afbc-4a94-9c34-8bd7c75b0845} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:793a6643-1712-489a-9b04-5b5f023f8e37'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:23.902474 [ 34277 ] {5b27dcfd-e75e-432f-a23c-397f985a9245} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 860, line 287) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:23.932152 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.009956 [ 3863 ] {220584ac-42fb-4fae-ae07-fd492f75f928} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:df17f185-7135-43f8-b72e-6b4224cc370a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53250) (comment: 00146_aggregate_function_uniq.sql) (in query: CREATE DATABASE IF NOT EXISTS test_u2no15pk ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.012231 [ 3863 ] {220584ac-42fb-4fae-ae07-fd492f75f928} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:df17f185-7135-43f8-b72e-6b4224cc370a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:24.152706 [ 10341 ] {c2b6c26a-b1cf-4d87-a235-7a7da4023f99} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:c987aaf1-9c97-4255-84f1-2cde49fdee49'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53256) (comment: 02125_tskv_proper_names_reading.sh) (in query: CREATE DATABASE IF NOT EXISTS test_878b1dgz ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.154524 [ 10341 ] {c2b6c26a-b1cf-4d87-a235-7a7da4023f99} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:c987aaf1-9c97-4255-84f1-2cde49fdee49'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:24.291930 [ 10341 ] {330b3f6a-0f02-49cc-be38-36ad7da4bd2a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:517d3346-ba64-4527-8965-e0ab92e518c5'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53272) (comment: 02244_column_names_in_shcmea_inference.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5f730a7o ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.303936 [ 10341 ] {330b3f6a-0f02-49cc-be38-36ad7da4bd2a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:517d3346-ba64-4527-8965-e0ab92e518c5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:24.499645 [ 3863 ] {ede0fa0d-8021-4d6c-ba9b-ab71492f1d36} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:8efb9001-ba56-471c-97a8-2858b7cdbf29'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53282) (comment: 01103_distributed_product_mode_local_column_renames.sql) (in query: CREATE DATABASE IF NOT EXISTS test_duf4jjsn ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.513242 [ 3863 ] {ede0fa0d-8021-4d6c-ba9b-ab71492f1d36} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:8efb9001-ba56-471c-97a8-2858b7cdbf29'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:24.658553 [ 57925 ] {82770444-ee2b-4462-a4ae-3144ee78d309} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:6d3479bf-2e84-486c-a3f9-6cfc1d5df76b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53290) (comment: 01297_create_quota.sql) (in query: CREATE DATABASE IF NOT EXISTS test_n15zob3k ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.672549 [ 57925 ] {82770444-ee2b-4462-a4ae-3144ee78d309} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:6d3479bf-2e84-486c-a3f9-6cfc1d5df76b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:24.811969 [ 6249 ] {8dbb7ed1-298c-4f33-aed3-9b1056961ba1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:471599b5-7d8a-4d9f-9aaf-d5e1f82dc0ad'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53294) (comment: 03128_system_unload_primary_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9vrunrn5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.816212 [ 6249 ] {8dbb7ed1-298c-4f33-aed3-9b1056961ba1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:471599b5-7d8a-4d9f-9aaf-d5e1f82dc0ad'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:24.947843 [ 57041 ] {eb60771e-2bd8-4f50-abc8-a1d2b6d8c04e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:259c6fca-6aa8-40c2-b799-5db1bf531ae7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53308) (comment: 02494_query_cache_drop_cache.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6d1gsjlc ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:24.950815 [ 57041 ] {eb60771e-2bd8-4f50-abc8-a1d2b6d8c04e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:259c6fca-6aa8-40c2-b799-5db1bf531ae7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:25.127366 [ 6249 ] {ff7234fb-673e-48c2-8523-26a3b72e973b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:592ce213-fb53-463c-9fae-9efcedc50f2a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53324) (comment: 02242_arrow_orc_parquet_nullable_schema_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_0pkagdbw ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:25.130186 [ 6249 ] {ff7234fb-673e-48c2-8523-26a3b72e973b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:592ce213-fb53-463c-9fae-9efcedc50f2a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:25.296627 [ 6249 ] {58c0ca92-a630-4763-b70b-5330590ded35} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:aee8bf9b-f088-4f25-97e9-23525804ae8a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53332) (comment: 00175_obfuscator_schema_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_khlb6pq5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:25.308824 [ 6249 ] {58c0ca92-a630-4763-b70b-5330590ded35} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:aee8bf9b-f088-4f25-97e9-23525804ae8a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:25.529600 [ 10341 ] {505e51e0-a0a8-4b00-baa1-97a1fbbeeb5b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4adcae85-94fd-4056-a55a-f25ad68cf36d'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53366) (comment: 02726_async_insert_flush_stress.sh) (in query: CREATE DATABASE IF NOT EXISTS test_qezhp1ya ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:25.532903 [ 10341 ] {505e51e0-a0a8-4b00-baa1-97a1fbbeeb5b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4adcae85-94fd-4056-a55a-f25ad68cf36d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:25.620331 [ 5826 ] {8d847ed3-99fa-402b-9775-7e2c14544487} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:36bb9f7a-a3bd-440e-947d-c1e53c3fec06'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53380) (comment: 01837_database_memory_ddl_dictionaries.sql) (in query: CREATE DATABASE IF NOT EXISTS test_jt8vun87 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:25.625955 [ 5826 ] {8d847ed3-99fa-402b-9775-7e2c14544487} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:36bb9f7a-a3bd-440e-947d-c1e53c3fec06'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:25.826109 [ 6249 ] {359cf7cf-e0bd-4bf7-a0fe-9c947480aea2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:0cbec907-b9a6-48d3-8583-afab9365686b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53386) (comment: 02918_fuzzjson_table_function.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5svdfxnj ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:25.829999 [ 6249 ] {359cf7cf-e0bd-4bf7-a0fe-9c947480aea2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:0cbec907-b9a6-48d3-8583-afab9365686b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:25.981643 [ 10341 ] {683cc1f0-12a2-4ab1-8fe3-f98032ec2a8a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:c6fb7d2e-50d0-4361-adc6-caffa28adfd1'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53396) (comment: 01889_sqlite_read_write.sh) (in query: CREATE DATABASE IF NOT EXISTS test_nnlskhxr ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:25.990595 [ 10341 ] {683cc1f0-12a2-4ab1-8fe3-f98032ec2a8a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:c6fb7d2e-50d0-4361-adc6-caffa28adfd1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:26.125203 [ 57041 ] {658ba2ed-5094-4ba8-8c2d-69f5b23a421b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:cdbc015d-22c8-4710-b3b9-e8e8ee7e2492'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53410) (comment: 02944_dynamically_change_filesystem_cache_size.sh) (in query: CREATE DATABASE IF NOT EXISTS test_c4z02pyy ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:26.128676 [ 57041 ] {658ba2ed-5094-4ba8-8c2d-69f5b23a421b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:cdbc015d-22c8-4710-b3b9-e8e8ee7e2492'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:26.178085 [ 4128 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:34:31: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:26.417103 [ 6249 ] {09611ad4-03b2-4c5a-ba2b-9354a727d92e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:a32c8893-a0ca-4cfe-9d74-3e8ba30e39b7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53412) (comment: 02185_values_schema_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_2i6qa7zg ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:26.421780 [ 6249 ] {09611ad4-03b2-4c5a-ba2b-9354a727d92e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:a32c8893-a0ca-4cfe-9d74-3e8ba30e39b7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:26.699166 [ 32979 ] {236347eb-9c6a-48eb-abe2-e5b3fe6c157b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4630eb10-850f-45d7-b0f9-7252bc24823a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53424) (comment: 00050_min_max.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ztmabonp ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:26.703166 [ 32979 ] {236347eb-9c6a-48eb-abe2-e5b3fe6c157b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4630eb10-850f-45d7-b0f9-7252bc24823a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:26.881265 [ 6249 ] {02b9d0b5-34b8-4e1a-9544-267bd8f55287} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:3096e4d4-6cda-4310-abe5-32b3fdc92248'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53430) (comment: 01076_parallel_alter_replicated_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_czqzjxl8 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:26.885747 [ 6249 ] {02b9d0b5-34b8-4e1a-9544-267bd8f55287} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:3096e4d4-6cda-4310-abe5-32b3fdc92248'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:27.003501 [ 6126 ] {60858b19-9351-4922-b639-2959c0962f55} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:47573534-2b04-4417-8b91-d895776f9250'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53434) (comment: 03254_test_alter_user_no_changes.sql) (in query: CREATE DATABASE IF NOT EXISTS test_usuw1mqq ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.006665 [ 6126 ] {60858b19-9351-4922-b639-2959c0962f55} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:47573534-2b04-4417-8b91-d895776f9250'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:27.111415 [ 10341 ] {197496b5-f613-4042-a526-9e4ef86bc52f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4868ea4b-3cdf-44f4-abfd-d2e5af0ed3ae'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53450) (comment: 01073_grant_and_revoke.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qco7tovu ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.121669 [ 10341 ] {197496b5-f613-4042-a526-9e4ef86bc52f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:4868ea4b-3cdf-44f4-abfd-d2e5af0ed3ae'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:27.224559 [ 6249 ] {7a6afe57-f1b6-4969-9697-1f4f4ef9627e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:446238a3-0ca6-4a2a-aad3-c52149bb7336'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53466) (comment: 01674_executable_dictionary_implicit_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nlvlfp6h ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.226621 [ 6249 ] {7a6afe57-f1b6-4969-9697-1f4f4ef9627e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '5c55fca0f983:9000:5dacfdaf-4c4f-4943-8264-3f6514e86c68', current host ID: '5c55fca0f983:9000:446238a3-0ca6-4a2a-aad3-c52149bb7336'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:27.320837 [ 3816 ] {5d4a5ad3-b5f6-4751-9bda-8447e06afb40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42424) (comment: 01558_ttest.sql) (query 20, line 25) (in query: SELECT roundBankers(welchTTest(left, right).1, 6) as t_stat, roundBankers(welchTTest(left, right).2, 6) as p_value from welch_ttest;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.351567 [ 3816 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.431085 [ 34277 ] {eb3cc291-235f-4d8d-ad2b-4518cf44ad05} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=857). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 876, line 292) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.460792 [ 34277 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=857). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.720928 [ 57041 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:27.724995 [ 57041 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.184485 [ 5382 ] {78ff363e-cd61-4459-9b13-3e55d3e2e000} executeQuery: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42596) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: INSERT INTO t_json_4 FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.198252 [ 5382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.223790 [ 5826 ] {1d28a525-48f1-4d5a-8c1b-63f1b3a25efb} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02126_fix_filelog.sh) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_95b1sb3m.file_log UUID '09047048-046b-4109-94a3-fa138aa07751' (`k` UInt8, `v` UInt8) ENGINE = FileLog('/tmp/aaa.csv', 'CSV')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.273995 [ 5826 ] {1d28a525-48f1-4d5a-8c1b-63f1b3a25efb} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42578) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.298977 [ 5826 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.533537 [ 5826 ] {d5ce2675-11b2-4b19-be92-ac8778156b7a} executeQuery: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42614) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: INSERT INTO t_json_4 FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.545749 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.546211 [ 10341 ] {61e6360d-ad95-44fb-aac3-56a101e2a33a} executeQuery: Code: 36. DB::Exception: Cannot DROP or CLEAR all columns. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01388_clear_all_columns.sql) (query 4, line 4) (in query: ALTER TABLE test CLEAR COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1760: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7291 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.565011 [ 10341 ] {} TCPHandler: Code: 36. DB::Exception: Cannot DROP or CLEAR all columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1760: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d7291 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.794408 [ 7056 ] {f33f9096-8141-4c2a-9c2e-dd969d51b40a} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02126_fix_filelog.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_95b1sb3m.file_log UUID 'ea754bb5-005d-4920-85ae-4a19063554a8' (`k` UInt8, `v` UInt8) ENGINE = FileLog('/tmp/aaa.csv', 'CSV')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.834171 [ 7056 ] {f33f9096-8141-4c2a-9c2e-dd969d51b40a} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42624) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.862860 [ 7056 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.962268 [ 34340 ] {466fca11-c91c-4772-873f-1c9ac2b15bde} executeQuery: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59050) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: INSERT INTO t_json_4 FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:28.995153 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.451380 [ 5826 ] {9e89edfa-8697-451d-8937-a938e6b8d093} executeQuery: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59092) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: INSERT INTO t_json_4 FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.456466 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.518431 [ 34340 ] {c3af0d50-70e4-4495-9941-6e4a1888be4e} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02126_fix_filelog.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_95b1sb3m.file_log UUID '0f0dad4c-253a-4500-a46f-7b89f15d912d' (`k` UInt8, `v` UInt8) ENGINE = FileLog('/tmp/aaa.csv', 'CSV')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.567953 [ 34340 ] {c3af0d50-70e4-4495-9941-6e4a1888be4e} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59088) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.580291 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7d742 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.810188 [ 10341 ] {120c4faa-79d0-4ed5-bd26-e275e4e820e1} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01388_clear_all_columns.sql) (query 10, line 14) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION '';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6344: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cdc6b9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd2e65 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.837536 [ 10341 ] {} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6344: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cdc6b9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd2e65 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.897977 [ 34340 ] {3a13ab8e-f606-45a8-bcba-6b94f160f3ac} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_4' in scope SELECT id, data, toTypeName(data) FROM t_json_4. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59108) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: SELECT id, data, toTypeName(data) FROM t_json_4), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.908060 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_4' in scope SELECT id, data, toTypeName(data) FROM t_json_4. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.936655 [ 10341 ] {d5a21129-1c14-4a8e-a15b-db9374f57c9c} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01388_clear_all_columns.sql) (query 11, line 15) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION 'asdasd';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6344: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cdc6b9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd2e65 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:29.960812 [ 10341 ] {} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6344: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cdc6b9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd2e65 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.159014 [ 10341 ] {736cd381-a0db-41bd-ac42-6b0069e02efe} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01388_clear_all_columns.sql) (query 12, line 16) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION '123';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6344: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cdc6b9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd2e65 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.171816 [ 10341 ] {} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6344: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cdc6b9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd2e65 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.257502 [ 10341 ] {d6fa8268-a6e1-466c-9805-e80f96b4c014} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01388_clear_all_columns.sql) (query 13, line 18) (in query: ALTER TABLE test CLEAR COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000030d78bcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3957: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd562b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.261691 [ 10341 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000030d78bcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3957: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd562b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.364120 [ 6022 ] {9449a7cc-f5de-4f6d-8961-de9efdceafdd} executeQuery: Code: 57. DB::Exception: Table test_v94w80n9.url_na_log already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50628) (comment: 02461_prewhere_row_level_policy_lightweight_delete.gen.sql) (query 54, line 139) (in query: CREATE TABLE url_na_log (`SiteId` UInt32, `DateVisit` Date) ENGINE = MergeTree PRIMARY KEY SiteId ORDER BY (SiteId, DateVisit) SETTINGS index_granularity = 9999, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 101, min_bytes_for_full_part_storage = 167798685, compact_parts_max_bytes_to_buffer = 468533236, compact_parts_max_granules_to_buffer = 212, compact_parts_merge_max_bytes_to_prefetch_part = 22906789, merge_max_block_size = 20865, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 625276018, 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 = 7722289, 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 = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 36562, primary_key_compress_block_size = 60001, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.390869 [ 6022 ] {} TCPHandler: Code: 57. DB::Exception: Table test_v94w80n9.url_na_log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.439818 [ 10341 ] {1fe0c318-e4f0-4796-ba2c-b3cedf7094f9} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01388_clear_all_columns.sql) (query 15, line 22) (in query: -- y is only real column in table ALTER TABLE test CLEAR COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000030d78bcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3957: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd562b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.445412 [ 10341 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000030d78bcf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3957: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd562b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.455037 [ 34340 ] {4cbc7086-9169-415c-a578-6fbddbda3a57} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_4' in scope SELECT id, data.k1 FROM t_json_4 ORDER BY id ASC. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59156) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: SELECT id, data.k1 FROM t_json_4 ORDER BY id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.472752 [ 34340 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_4' in scope SELECT id, data.k1 FROM t_json_4 ORDER BY id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.631762 [ 6126 ] {3102dafe-ac31-4b6d-bb5a-ca3c379567a7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42606) (comment: 02461_prewhere_row_level_policy_lightweight_delete.gen.sql) (in query: DROP DATABASE IF EXISTS test_v94w80n9 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:30.644823 [ 6126 ] {3102dafe-ac31-4b6d-bb5a-ca3c379567a7} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:31.111869 [ 6126 ] {54e48f85-6ef1-42cc-b112-c089ac22cacc} executeQuery: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59172) (comment: 01825_type_json_4.sh) (query 1, line 1) (in query: DROP TABLE t_json_4), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:31.136651 [ 6126 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qlwei573.t_json_4 does not exist. Maybe you meant test_11.t_json_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0b8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e5047 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:31.455675 [ 7056 ] {31a9ddab-8e68-452c-a816-54b78d7975a8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02126_fix_filelog.sh) (in query: /* ddl_entry=query-0000000006 */ TRUNCATE TABLE test_95b1sb3m.file_log), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:34:31.492306 [ 7056 ] {31a9ddab-8e68-452c-a816-54b78d7975a8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59188) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: drop table file_log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:34:31.510124 [ 7056 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5d2476 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5cf705 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7bf302 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c7838aa 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2696 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:34:31.822334 [ 6126 ] {0b91cb28-d98e-43cf-9958-d3f4e2d7a194} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42662) (comment: 02126_fix_filelog.sh) (in query: DROP DATABASE IF EXISTS test_95b1sb3m SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:31.833860 [ 6126 ] {0b91cb28-d98e-43cf-9958-d3f4e2d7a194} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:32.040645 [ 5382 ] {c10a0d6b-5dfa-4199-951b-7a6b70226983} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:c86efa26-bd05-46b6-a81d-12a40a2d2dbd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42670) (comment: 02994_libarchive_compression.sh) (in query: CREATE DATABASE IF NOT EXISTS test_1tl7t4kw ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:32.042974 [ 5382 ] {c10a0d6b-5dfa-4199-951b-7a6b70226983} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:c86efa26-bd05-46b6-a81d-12a40a2d2dbd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:32.242794 [ 34277 ] {23e0adb7-bd5b-460d-86a5-409997c05975} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 896, line 299) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:32.254387 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:32.302278 [ 46285 ] {bae1616a-1db8-4bda-934c-400ad9a860dd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:4caf56f6-82ba-4665-b38b-5b1dca9b9abf'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42676) (comment: 00189_time_zones_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_el6xky45 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:32.316043 [ 46285 ] {bae1616a-1db8-4bda-934c-400ad9a860dd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:4caf56f6-82ba-4665-b38b-5b1dca9b9abf'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:32.532136 [ 7056 ] {f777d2c6-b273-4989-a145-febd9528198d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:52eb659a-05a6-474b-af21-c0e225ec7b21'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42686) (comment: 00098_6_union_all.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wjn8pmdz ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:32.536794 [ 7056 ] {f777d2c6-b273-4989-a145-febd9528198d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:52eb659a-05a6-474b-af21-c0e225ec7b21'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:32.964681 [ 7056 ] {2331a529-5902-465c-8cb6-e3409bf2b0a1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:9909f0d2-4a6b-4798-984b-d0cb5e22b960'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42700) (comment: 02269_to_start_of_interval_overflow.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wri6s91d ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:32.967941 [ 7056 ] {2331a529-5902-465c-8cb6-e3409bf2b0a1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:9909f0d2-4a6b-4798-984b-d0cb5e22b960'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:33.175459 [ 6024 ] {1c9a7703-893a-42f3-afab-df1949e96533} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:5903cdda-3794-4924-bfc4-58490803eb07'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42712) (comment: 02254_projection_broken_part.sh) (in query: CREATE DATABASE IF NOT EXISTS test_hqvebohm ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:33.191172 [ 6024 ] {1c9a7703-893a-42f3-afab-df1949e96533} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:5903cdda-3794-4924-bfc4-58490803eb07'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:33.494301 [ 5382 ] {a8902260-d02a-4f5d-9655-6f681dbe3485} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f674a5b9-b9ed-4843-a4bb-0584f5f8339f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42742) (comment: 02721_url_cluster.sql) (in query: CREATE DATABASE IF NOT EXISTS test_vaotctb2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:33.502422 [ 5382 ] {a8902260-d02a-4f5d-9655-6f681dbe3485} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f674a5b9-b9ed-4843-a4bb-0584f5f8339f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:33.692821 [ 46286 ] {d35f31f7-c0aa-4aa6-8656-7b4433ac6522} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:63eb1822-c6ce-4a1f-97f1-07cd8f834ad9'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42748) (comment: 00152_totals_in_subquery.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8fwl5gba ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:33.698203 [ 46286 ] {d35f31f7-c0aa-4aa6-8656-7b4433ac6522} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:63eb1822-c6ce-4a1f-97f1-07cd8f834ad9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:33.943672 [ 46285 ] {749af625-4484-4b0d-abd8-1e7f26dde029} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:bd6f1137-d771-4991-9da3-d88311d8184f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42758) (comment: 01031_mutations_interpreter_and_context.sh) (in query: CREATE DATABASE IF NOT EXISTS test_cacs3gos ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:33.947653 [ 46285 ] {749af625-4484-4b0d-abd8-1e7f26dde029} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:bd6f1137-d771-4991-9da3-d88311d8184f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:34.106345 [ 46285 ] {6745a095-9895-4ba1-90aa-cbefe8d4874c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:9457eb5b-eba5-4b03-ba47-cb11d927d893'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42772) (comment: 01787_arena_assert_column_nothing.sql) (in query: CREATE DATABASE IF NOT EXISTS test_kddkpc5v ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:34.116948 [ 46285 ] {6745a095-9895-4ba1-90aa-cbefe8d4874c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:9457eb5b-eba5-4b03-ba47-cb11d927d893'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:34.199299 [ 3766 ] {806191bf-a89d-4b19-87de-96b99aa1b6aa} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:8c77a94a-c2a8-4001-bc96-048a8f2de77c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42784) (comment: 00753_alter_attach.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l2x5o5wp ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:34.203684 [ 3766 ] {806191bf-a89d-4b19-87de-96b99aa1b6aa} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:8c77a94a-c2a8-4001-bc96-048a8f2de77c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:34.351133 [ 46285 ] {c01760a7-183e-4d50-af1c-b8c25b34cb6d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:008553ba-6aea-4097-93ca-5861861ab5a0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42802) (comment: 03268_system_parts_index_granularity.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hk2ufqnk ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:34.355367 [ 46285 ] {c01760a7-183e-4d50-af1c-b8c25b34cb6d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:008553ba-6aea-4097-93ca-5861861ab5a0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:34.476458 [ 3766 ] {135c4495-fc43-4630-9fad-250a57bffd48} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:13fada00-3530-4388-a948-5d8d61c239d5'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42816) (comment: 03311_constantnode.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tg72mgca ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:34.486027 [ 3766 ] {135c4495-fc43-4630-9fad-250a57bffd48} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:13fada00-3530-4388-a948-5d8d61c239d5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:34.656188 [ 5382 ] {0e6ef575-6ed4-4ce6-85ee-27c1628c4aeb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:ad7a2448-09b7-4827-bfe3-ee933b31efcf'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42824) (comment: 01490_nullable_string_to_enum.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lg2n33yj ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:34.663273 [ 5382 ] {0e6ef575-6ed4-4ce6-85ee-27c1628c4aeb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:ad7a2448-09b7-4827-bfe3-ee933b31efcf'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:34.857701 [ 46285 ] {4105c59e-9d1a-4a3e-8c58-c23677a5e25d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:5edd81fb-2d88-4969-a022-0fddf5e58584'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42842) (comment: 00802_daylight_saving_time_shift_backwards_at_midnight.sql) (in query: CREATE DATABASE IF NOT EXISTS test_alm2t9e1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:34.861609 [ 46285 ] {4105c59e-9d1a-4a3e-8c58-c23677a5e25d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:5edd81fb-2d88-4969-a022-0fddf5e58584'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:35.056297 [ 7056 ] {78bab174-6e7e-4ee4-a28d-e48e1ecafa94} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:daaf1678-b5fe-4349-9a58-65609ceda556'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42850) (comment: 02294_decimal_second_errors.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pwj28o3e ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:35.069105 [ 7056 ] {78bab174-6e7e-4ee4-a28d-e48e1ecafa94} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:daaf1678-b5fe-4349-9a58-65609ceda556'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:35.292860 [ 5380 ] {881e5fec-2119-4dfb-acef-0b4756e7a6bc} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:1318ccec-1a24-4778-b282-2155d58d6e91'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42880) (comment: 02421_type_json_async_insert.sh) (in query: CREATE DATABASE IF NOT EXISTS test_e8ryabw0 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:35.359862 [ 5380 ] {881e5fec-2119-4dfb-acef-0b4756e7a6bc} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:1318ccec-1a24-4778-b282-2155d58d6e91'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:35.658375 [ 5380 ] {3cb5baad-33f3-490d-9f8f-788cdb2a376f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:9b81bb98-41f9-4773-9cdd-2094e0507b3f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42902) (comment: 02113_untuple_func_alias.sql) (in query: CREATE DATABASE IF NOT EXISTS test_45h90s9f ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:35.660142 [ 5380 ] {3cb5baad-33f3-490d-9f8f-788cdb2a376f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:9b81bb98-41f9-4773-9cdd-2094e0507b3f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:35.792316 [ 46282 ] {2e163c04-3819-4834-9123-0a36ee3b78d0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:03667a97-9059-4a09-89a7-964ff3090bd8'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42906) (comment: 02538_analyzer_create_table_as_select.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0bnt8kdp ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:35.800919 [ 46282 ] {2e163c04-3819-4834-9123-0a36ee3b78d0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:03667a97-9059-4a09-89a7-964ff3090bd8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:35.989268 [ 46282 ] {d96a0de8-fedc-4a78-b46a-44dc0cd86967} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:420c23d8-a220-4f82-a128-56876e275cf0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42916) (comment: 01457_order_by_nulls_first.sql) (in query: CREATE DATABASE IF NOT EXISTS test_aih27lub ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:35.997743 [ 46282 ] {d96a0de8-fedc-4a78-b46a-44dc0cd86967} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:420c23d8-a220-4f82-a128-56876e275cf0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:36.052397 [ 34277 ] {5a43a5b8-63cf-40dd-b311-0cf6b438aeb6} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 911, line 304) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.080974 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.198923 [ 7091 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:34:42: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:36.232384 [ 46282 ] {16224bf9-56b9-41e7-a022-c33cc0652669} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:0e11978c-4bf7-41d2-884d-6e7b7af4c540'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42926) (comment: 00151_order_by_read_in_order.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i5pns5s2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.234511 [ 46282 ] {16224bf9-56b9-41e7-a022-c33cc0652669} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:0e11978c-4bf7-41d2-884d-6e7b7af4c540'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:36.319858 [ 57039 ] {82431d2b-902a-468f-9fa8-09d2ae2c5266} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:fa3e16d3-bb43-4599-8629-463c5e6bbe58'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42942) (comment: 02944_dynamically_change_filesystem_cache_size.sh) (in query: CREATE DATABASE IF NOT EXISTS test_7j379qjr ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.325979 [ 57039 ] {82431d2b-902a-468f-9fa8-09d2ae2c5266} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:fa3e16d3-bb43-4599-8629-463c5e6bbe58'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:36.407436 [ 57039 ] {d510e3a0-fd8a-4392-b9bb-a96368ac5449} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:c805ed30-e987-4dbb-8219-82335e48a2f9'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42958) (comment: 02207_allow_plaintext_and_no_password.sh) (in query: CREATE DATABASE IF NOT EXISTS test_60btgujd ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.410540 [ 57039 ] {d510e3a0-fd8a-4392-b9bb-a96368ac5449} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:c805ed30-e987-4dbb-8219-82335e48a2f9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:36.663435 [ 3815 ] {e1e7a4b5-8ca7-43b9-87d4-45b1e51aef94} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:444418ab-b630-4b72-aeef-82dcc46ef6b8'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42968) (comment: 00002_count_visits.sql) (in query: CREATE DATABASE IF NOT EXISTS test_78e6x9uo ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.749352 [ 3815 ] {e1e7a4b5-8ca7-43b9-87d4-45b1e51aef94} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:444418ab-b630-4b72-aeef-82dcc46ef6b8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:36.895757 [ 46285 ] {eb898180-b710-4d66-83aa-510d04d0c829} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:3da87182-927c-45f6-958b-9014f1fa62f4'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42990) (comment: 00098_primary_key_memory_allocated.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3xfw6rcc ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:36.897952 [ 46285 ] {eb898180-b710-4d66-83aa-510d04d0c829} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:3da87182-927c-45f6-958b-9014f1fa62f4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.073153 [ 34273 ] {87b7d052-b82b-47f9-ba5c-50ef5ffe9d30} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:fdda75d7-ac76-45c5-87f4-56f04675c0d7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43000) (comment: 00050_min_max.sql) (in query: CREATE DATABASE IF NOT EXISTS test_oztiy9r9 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:37.082472 [ 34273 ] {87b7d052-b82b-47f9-ba5c-50ef5ffe9d30} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:fdda75d7-ac76-45c5-87f4-56f04675c0d7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.325316 [ 57039 ] {eca66dff-df2d-4638-a13f-0132637ab608} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:aa3c2365-0c8f-4932-a020-fde1f2af37b3'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43014) (comment: 02705_capnp_more_types.sh) (in query: CREATE DATABASE IF NOT EXISTS test_2qp5dhqd ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:37.329398 [ 57039 ] {eca66dff-df2d-4638-a13f-0132637ab608} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:aa3c2365-0c8f-4932-a020-fde1f2af37b3'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.531490 [ 34273 ] {608de6a6-3269-44cd-834c-6b881d32cbf1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:35143de9-1c50-428c-8e9c-7c724d164dc8'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43022) (comment: 00166_explain_estimate.sql) (in query: CREATE DATABASE IF NOT EXISTS test_vonzcqq5 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:37.544619 [ 34273 ] {608de6a6-3269-44cd-834c-6b881d32cbf1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:35143de9-1c50-428c-8e9c-7c724d164dc8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.643020 [ 57039 ] {dc2bc411-dc4d-4b86-bc35-cad78276591c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:8a56037f-2277-4be1-b915-f7f3cf794674'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43030) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: CREATE DATABASE IF NOT EXISTS test_9bm2ubw1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:37.653024 [ 57039 ] {dc2bc411-dc4d-4b86-bc35-cad78276591c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:8a56037f-2277-4be1-b915-f7f3cf794674'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.740084 [ 57925 ] {a7b13a23-85e9-4632-b084-0fb3122b6af5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:ad2ca7e9-659d-442c-a5ee-2286388236ac'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43032) (comment: 01320_create_sync_race_condition_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_psclrank ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:37.742956 [ 57925 ] {a7b13a23-85e9-4632-b084-0fb3122b6af5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:ad2ca7e9-659d-442c-a5ee-2286388236ac'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.854192 [ 57039 ] {aadb6ae3-a6f9-4b61-a7ab-16d1f8da9603} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:a1239d94-7d40-4049-b26e-65b161e11bbc'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43042) (comment: 02404_memory_bound_merging.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2pc72l6u ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:37.856576 [ 57039 ] {aadb6ae3-a6f9-4b61-a7ab-16d1f8da9603} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:a1239d94-7d40-4049-b26e-65b161e11bbc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:37.903088 [ 5105 ] {11935741-66a4-4a06-8ab7-d27e111c586f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:59458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 16. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 17. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 18. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:34:37.998124 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc053ce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 16. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 17. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 18. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:34:38.012628 [ 57039 ] {902b08af-9fa6-4b8c-a5a1-c74ab658a8c3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:8fe717ea-57d6-4b92-8909-fe0c5679664e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43052) (comment: 00020_distinct_order_by_distributed.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nq89i1q6 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.015626 [ 57039 ] {902b08af-9fa6-4b8c-a5a1-c74ab658a8c3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:8fe717ea-57d6-4b92-8909-fe0c5679664e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:38.248509 [ 5380 ] {50b968b6-2101-49d8-8b84-a6943d699ece} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59384) (comment: 02200_use_skip_indexes.sql) (query 4, line 14) (in query: SELECT * FROM data_02200 WHERE value = 1 SETTINGS use_skip_indexes=0, max_rows_to_read=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.262521 [ 5380 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.304208 [ 34273 ] {0fe2d34f-2d80-4d98-af4b-cf43433379a7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f30a0e71-766c-4cb0-8247-873fb572810b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43068) (comment: 00693_max_block_size_system_tables_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_x310t2ik ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.308572 [ 34273 ] {0fe2d34f-2d80-4d98-af4b-cf43433379a7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f30a0e71-766c-4cb0-8247-873fb572810b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:38.476779 [ 5971 ] {17109feb-e620-4fb6-877d-71a3d0c2ebd0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:abafcc4a-035d-462f-9c06-eaee5f978293'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43092) (comment: 02244_lowcardinality_hash_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_r7w32klu ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.485124 [ 5971 ] {17109feb-e620-4fb6-877d-71a3d0c2ebd0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:abafcc4a-035d-462f-9c06-eaee5f978293'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:38.600084 [ 3816 ] {e60b6459-3075-470a-a7bd-eb0647b81023} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:cfa8f0fa-434b-4a75-99ce-0e5e9c5ab8fb'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43114) (comment: 00068_subquery_in_prewhere.sql) (in query: CREATE DATABASE IF NOT EXISTS test_cclexy94 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.605734 [ 3816 ] {e60b6459-3075-470a-a7bd-eb0647b81023} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:cfa8f0fa-434b-4a75-99ce-0e5e9c5ab8fb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:38.716805 [ 57041 ] {8bb7aa74-c192-4154-beed-1d79f7b4347b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f71113f8-0075-4d6e-a123-c78b9940297c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43136) (comment: 00172_hits_joins.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_a2aht1xk ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.741152 [ 57041 ] {8bb7aa74-c192-4154-beed-1d79f7b4347b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f71113f8-0075-4d6e-a123-c78b9940297c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:38.817495 [ 5105 ] {fb3717f0-83dd-4159-9dd5-ffd9b99982bb} 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.3.20372.altinityantalya (altinity build)) (from [::1]:59458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 14. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 16. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:34:38.828582 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 14. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 16. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:34:38.931127 [ 34273 ] {acb9a0a1-341b-446b-8946-5cfdfac4095f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f63bd605-2e96-4448-b97b-f9e92c7badf7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55078) (comment: 02541_arrow_duration_type.sh) (in query: CREATE DATABASE IF NOT EXISTS test_nr2eoj9z ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:38.939295 [ 34273 ] {acb9a0a1-341b-446b-8946-5cfdfac4095f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:f63bd605-2e96-4448-b97b-f9e92c7badf7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:39.042228 [ 5105 ] {24719aef-90b9-494d-a9be-8e2162a85188} 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.3.20372.altinityantalya (altinity build)) (from [::1]:59458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5855: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0a0fc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:186: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02ce7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 16. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 17. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 18. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:34:39.049468 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5855: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc0a0fc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:186: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02ce7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 16. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 17. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 18. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:34:39.177634 [ 3863 ] {d0b492b3-56ec-4233-89c7-fbf725e63092} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:06985d82-4e67-4d2d-b6f9-035c2a1c2b3d'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55094) (comment: 02286_use_file_descriptor_in_table_function_file.sh) (in query: CREATE DATABASE IF NOT EXISTS test_kwy4gwzi ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.193784 [ 3863 ] {d0b492b3-56ec-4233-89c7-fbf725e63092} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:06985d82-4e67-4d2d-b6f9-035c2a1c2b3d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:39.221218 [ 34277 ] {a2e99984-653c-41bf-a239-cbc913785ceb} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 926, line 309) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.229033 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.293556 [ 6022 ] {3c486296-edeb-4942-a771-e96d572dca62} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:1c089327-c430-4c03-bda2-2e9e8d2ee317'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55104) (comment: 01083_expressions_in_engine_arguments.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0czk34fb ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.303692 [ 6022 ] {3c486296-edeb-4942-a771-e96d572dca62} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:1c089327-c430-4c03-bda2-2e9e8d2ee317'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:39.426478 [ 5105 ] {972a0e36-816b-42e9-88e7-f6172cbdc338} 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.3.20372.altinityantalya (altinity build)) (from [::1]:59458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1247: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c65 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4766: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc13771 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:34:39.430996 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1247: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc27c65 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc28f56 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4766: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc13771 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:34:39.504436 [ 57925 ] {99996c54-0493-45b7-a17e-a7879a1403f2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:bb2a6907-2cdb-4dd6-9a21-826ccd4bd27e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55112) (comment: 00004_top_counters.sql) (in query: CREATE DATABASE IF NOT EXISTS test_k4bhldg8 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.600340 [ 34273 ] {4841af4c-5ace-4b1a-a115-3b3f10f4de02} executeQuery: Code: 128. DB::Exception: Array size 96142475 with element size 21 bytes is too large: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(96142475, ['qMUF']). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42778) (comment: 03216_arrayWithConstant_limits.sql) (query 1, line 1) (in query: SELECT arrayWithConstant(96142475, ['qMUF']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000002327baaf 5. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002327b2ac 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:34:39.607844 [ 57925 ] {99996c54-0493-45b7-a17e-a7879a1403f2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '5c55fca0f983:9000:8d5a8f2f-9c4b-4950-9aa2-81c962a11aca', current host ID: '5c55fca0f983:9000:bb2a6907-2cdb-4dd6-9a21-826ccd4bd27e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c7a7437 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c76b1e6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c771887 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dca6d9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc604af 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:39.610479 [ 34273 ] {} TCPHandler: Code: 128. DB::Exception: Array size 96142475 with element size 21 bytes is too large: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(96142475, ['qMUF']). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000002327baaf 5. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002327b2ac 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:34:39.814339 [ 5105 ] {ae9544d0-23c9-4d9f-a440-2b0242568c5f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:59458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 26. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 27. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 28. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 29. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 2025.07.13 02:34:39.821221 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 26. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 27. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 28. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 29. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc14484 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 2025.07.13 02:34:39.913051 [ 34273 ] {6d6cb75f-cc80-4177-a11c-ad45644e285f} executeQuery: Code: 128. DB::Exception: Array size 100000000 with element size 102 bytes is too large: while executing function arrayWithConstant: while executing 'FUNCTION arrayWithConstant(100000000_UInt32 :: 1, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String)) :: 3) -> arrayWithConstant(100000000_UInt32, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String))) Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))) : 2'. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42778) (comment: 03216_arrayWithConstant_limits.sql) (query 2, line 2) (in query: SELECT arrayWithConstant(100000000, materialize([[[[[[[[[['Hello, world!']]]]]]]]]]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000002327baaf 5. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002327b2ac 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.938439 [ 34273 ] {} TCPHandler: Code: 128. DB::Exception: Array size 100000000 with element size 102 bytes is too large: while executing function arrayWithConstant: while executing 'FUNCTION arrayWithConstant(100000000_UInt32 :: 1, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String)) :: 3) -> arrayWithConstant(100000000_UInt32, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String))) Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))) : 2'. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000002327baaf 5. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002327b2ac 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:39.966157 [ 5105 ] {4866862c-564c-4647-9c36-821a9ad658b8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `DEFAULT` in scope (SELECT DEFAULT FROM system.one) AS constant_expression. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59458) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 14. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 16. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a3d50 17. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a33a9 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 19. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:34:39.994005 [ 5105 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc19eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc18f84 14. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 16. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a3d50 17. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a33a9 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 19. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 2025.07.13 02:34:41.220571 [ 5825 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:36:38: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c0475 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:42.601580 [ 5971 ] {25cc0c7c-799d-45a2-85f4-87af98b990fe} executeQuery: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42808) (comment: 01451_detach_drop_part.sql) (query 8, line 12) (in query: ALTER TABLE mt_01451 DETACH PART 'all_100_100_0';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5458: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x0000000030d080e1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5685: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f45e 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:42.612507 [ 5971 ] {} TCPHandler: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5458: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x0000000030d080e1 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5685: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0f45e 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:43.106157 [ 34277 ] {9487e292-c32e-4e41-a5a5-58744f4277fd} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 941, line 314) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:43.111064 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:43.413047 [ 34277 ] {35552c1f-8902-40a8-b985-aa0a22e8b378} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 944, line 315) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:43.430867 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:44.658429 [ 5971 ] {11e26247-a4fa-45bc-aa14-5bc18de90c4c} executeQuery: Code: 233. DB::Exception: Detached part "all_4_4_0" not found. (BAD_DATA_PART_NAME) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42808) (comment: 01451_detach_drop_part.sql) (query 17, line 30) (in query: ALTER TABLE mt_01451 ATTACH PART 'all_4_4_0';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7965: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x0000000030d20bb2 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6764: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x0000000030d2211b 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:2184: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000031208d84 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5705: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e178 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:44.661430 [ 5971 ] {} TCPHandler: Code: 233. DB::Exception: Detached part "all_4_4_0" not found. (BAD_DATA_PART_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7965: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x0000000030d20bb2 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6764: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x0000000030d2211b 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:2184: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000031208d84 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5705: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e178 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:34:45.130707 [ 3480 ] {} test_7e5kyfth.r2 (c4346209-3b21-4d4f-8362-b21d10bc50c9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://5c55fca0f983:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_7e5kyfth%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6d93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6db2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6d821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028511f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028512404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285132a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028517d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850e5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028515729 13. DB::ReadBuffer::next() @ 0x0000000017e75832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285112d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285022b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ae4ee5 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000030737cbe 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030609a7c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305f57e8 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305e045f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030733bc5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003112d474 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030640ddf 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000030735568 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b40a3c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6e39d 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c6efdf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:45.342541 [ 36854 ] {ba414c53-4094-4910-89cd-9a2fe7457f00} BackupsWorker: Failed to restore from backup Null: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002bfa1ea6 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf4e2f0 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4f0cf 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 11. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf47eb4 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476c8 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:45.346479 [ 5382 ] {ba414c53-4094-4910-89cd-9a2fe7457f00} executeQuery: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42886) (comment: 03286_backup_to_null.sql) (query 6, line 10) (in query: RESTORE TABLE t1 FROM Null FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002bfa1ea6 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf4e2f0 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4f0cf 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 11. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:45.350427 [ 5382 ] {} TCPHandler: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002bfa1ea6 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf4e2f0 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4f0cf 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf62012 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf56fc3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b840afc 11. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b840f32 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b83fc59 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b83fab7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf47eb4 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf476c8 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e37abfc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:34:45.648309 [ 3477 ] {} test_7e5kyfth.r2 (c4346209-3b21-4d4f-8362-b21d10bc50c9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://5c55fca0f983:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_7e5kyfth%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6d93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6db2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6d821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028511f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028512404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285132a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028517d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850e5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028515729 13. DB::ReadBuffer::next() @ 0x0000000017e75832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285112d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285022b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ae4ee5 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000030737cbe 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030609a7c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305f57e8 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305e045f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030733bc5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003112d474 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030640ddf 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000030735568 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b40a3c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6e39d 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c6efdf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:45.935018 [ 3478 ] {} test_7e5kyfth.r2 (c4346209-3b21-4d4f-8362-b21d10bc50c9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://5c55fca0f983:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_7e5kyfth%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6d93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6db2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6d821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028511f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028512404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285132a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028517d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850e5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028515729 13. DB::ReadBuffer::next() @ 0x0000000017e75832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285112d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285022b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ae4ee5 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000030737cbe 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030609a7c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305f57e8 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305e045f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030733bc5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003112d474 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030640ddf 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000030735568 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b40a3c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6e39d 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c6efdf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:46.281694 [ 7216 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:34:54: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:46.411044 [ 3487 ] {} test_7e5kyfth.r2 (c4346209-3b21-4d4f-8362-b21d10bc50c9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://5c55fca0f983:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_7e5kyfth%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6d93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6db2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6d821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028511f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028512404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285132a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028517d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850e5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028515729 13. DB::ReadBuffer::next() @ 0x0000000017e75832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285112d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285022b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ae4ee5 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000030737cbe 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030609a7c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305f57e8 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305e045f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030733bc5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003112d474 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030640ddf 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000030735568 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b40a3c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6e39d 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c6efdf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:48.425184 [ 34277 ] {45bb95ce-9eca-4210-b266-20e56b12a8f6} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 965, line 322) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:48.463403 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:50.318631 [ 34277 ] {db67573e-2bf0-412e-92ab-686d99607074} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 971, line 324) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:50.336917 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:51.518617 [ 46286 ] {172a003b-946b-4d78-9684-209f3e7b3755} executeQuery: Code: 290. DB::Exception: Too many grace hash join buckets (2048 > 1024), consider increasing grace_hash_join_max_buckets or max_rows_in_join/max_bytes_in_join: While executing DelayedJoinedBlocksTransform. (LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59342) (comment: 03277_join_adaptive_spill.sql) (query 11, line 15) (in query: select * from (select t1.k as k, t1.x as x1, t2.x as x2, t3.x as x3 from adaptive_spill_03277_1 as t1 left join adaptive_spill_03277_2 as t2 on t1.k = t2.k left join adaptive_spill_03277_3 as t3 on t1.k = t3.k) order by k, x1, x2, x3 limit 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000001a6a5e6f 5. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:364: DB::GraceHashJoin::rehashBuckets() @ 0x000000002dc28c5a 6. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:731: DB::GraceHashJoin::addBlockToJoinImpl(DB::Block) @ 0x000000002dc25ece 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:662: DB::GraceHashJoin::getDelayedBlocks() @ 0x000000002dc2c700 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:532: DB::DelayedJoinedBlocksTransform::work() @ 0x0000000031ddc3c0 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:52.340008 [ 34277 ] {67f724d3-2317-450d-a6b8-a37b579dcb31} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 980, line 327) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:52.347719 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:53.158968 [ 5826 ] {9b2a212b-2a3a-44c9-b38a-008d079f74fa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57396) (comment: 00502_sum_map.sql) (query 10, line 14) (in query: SELECT timeslot, sumMap(statusMap.status, statusMap.requests).1, sumMap(statusMap.status, statusMap.requests).2 FROM sum_map GROUP BY timeslot ORDER BY timeslot;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:53.175640 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:53.880031 [ 5826 ] {71008e5a-24dc-4a19-b91d-4ac13ac9d543} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57482) (comment: 01825_type_json_distributed.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:53.892875 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:54.583072 [ 5826 ] {5619d117-e2d9-42da-9c21-68b6a35b670f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57526) (comment: 01070_exception_code_in_query_log_table.sql) (query 2, line 2) (in query: SELECT * FROM test_table_for_01070_exception_code_in_query_log_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:54.592610 [ 5826 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:34:54.647563 [ 6022 ] {ec0f7821-69b4-4ae0-b9ae-2c36756d71ed} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float64, String because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42958) (comment: 03224_arrayUnion.sql) (query 36, line 46) (in query: --mix of types SELECT arrayUnion([1], [-2], [1.1, 'hi'], [NULL, 'hello', []]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002c4de745 7. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ca94bda 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ConstantNode* std::construct_at[abi:ne190107](DB::ConstantNode*, DB::Field const&) @ 0x000000002cbd0806 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::Field const&) @ 0x000000002cbd06bf 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x000000002cbd053a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba7fc8 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba8af5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 17. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 18. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:34:54.652409 [ 6022 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float64, String 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c51efd8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c524423 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002c4de745 7. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ca94bda 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ConstantNode* std::construct_at[abi:ne190107](DB::ConstantNode*, DB::Field const&) @ 0x000000002cbd0806 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::Field const&) @ 0x000000002cbd06bf 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x000000002cbd053a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba7fc8 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba8af5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba6db6 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbacd36 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5fe5 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbab4da 17. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba5aa0 18. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cba52fc 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f3a0 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:34:54.686312 [ 34277 ] {5a059f92-fc6b-4aee-b2f4-21dd01ec9ed5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 992, line 331) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:34:54.709631 [ 34277 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:34:54.763752 [ 34277 ] {e8898b17-65c8-4402-b25a-c4127056b691} executeQuery: Code: 60. DB::Exception: Table test_13.mt_00763_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 993, line 331) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:54.770542 [ 34277 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.mt_00763_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dce5184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d37 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:34:55.093926 [ 6022 ] {107a327e-b32e-4f81-9ddc-30fbb3c86e09} executeQuery: Code: 42. DB::Exception: Function arrayUnion requires at least one argument.: In scope SELECT arrayUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42958) (comment: 03224_arrayUnion.sql) (query 39, line 50) (in query: SELECT arrayUnion();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000022e4f724 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:34:55.096482 [ 6022 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayUnion requires at least one argument.: In scope SELECT arrayUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000022e4f724 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:34:55.159473 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:56.299590 [ 5228 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:35:08: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:34:57.433686 [ 46286 ] {} TCPHandler: Code: 290. DB::Exception: Too many grace hash join buckets (2048 > 1024), consider increasing grace_hash_join_max_buckets or max_rows_in_join/max_bytes_in_join: While executing DelayedJoinedBlocksTransform. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000001a6a5e6f 5. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:364: DB::GraceHashJoin::rehashBuckets() @ 0x000000002dc28c5a 6. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:731: DB::GraceHashJoin::addBlockToJoinImpl(DB::Block) @ 0x000000002dc25ece 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:662: DB::GraceHashJoin::getDelayedBlocks() @ 0x000000002dc2c700 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:532: DB::DelayedJoinedBlocksTransform::work() @ 0x0000000031ddc3c0 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:34:58.646994 [ 36699 ] {f8a18385-ff2f-41c1-ac7c-26bc833633d2} HashedDictionary: 'prellocate' attribute is obsolete, consider looking at 'shards' 2025.07.13 02:34:58.670611 [ 34277 ] {904e1c1a-0179-45dc-b853-039b8bc97d86} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1013, line 338) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:58.678764 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:59.138756 [ 34277 ] {04f22564-8fd3-40ea-82c8-e12f79b12d34} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1016, line 339) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:34:59.145000 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:00.094035 [ 5382 ] {74acf5e6-50f3-4f1d-9f89-c93d89ee91d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=853). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42592) (comment: 01508_partition_pruning_long_2.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from xMM where a = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:00.155589 [ 5382 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=853). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:01.982437 [ 5826 ] {133668c9-c6fe-4dca-b8a3-a3da92fa99dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42606) (comment: 01646_fix_window_funnel_inconistency.sql) (query 8, line 35) (in query: SELECT level, count() AS c FROM ( SELECT user_id, windowFunnel(6048000000000000)(timestamp, eventID = 1004, eventID = 1003, eventID = 1002) AS level FROM trend GROUP BY user_id ) GROUP BY level ORDER BY level ASC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:01.993545 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:02.347616 [ 5480 ] {5a9aadd5-3622-40dd-a71f-f168c59b16f0} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:02.362440 [ 5480 ] {5a9aadd5-3622-40dd-a71f-f168c59b16f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57634) (comment: 00855_join_with_array_join.sql) (query 18, line 32) (in query: SELECT id, name FROM f LEFT ARRAY JOIN d_ids as id LEFT JOIN d ON d.id = id ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:35:02.378868 [ 5480 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc4b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db92065 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02f59 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002de02d6e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddff6f6 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000032146829 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032299ae6 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289f4a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:35:02.516421 [ 5826 ] {dc20a70c-5544-4178-8e47-3c7f4e7fdc6f} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 1, line 1) (in query: SELECT bitAnd(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019051b33 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018f529b1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:02.530608 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019051b33 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018f529b1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:02.758005 [ 34277 ] {7505d70e-aabd-4f66-b883-b07b14f04a8f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1034, line 345) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:02.767152 [ 5826 ] {41bca55d-fbdb-4aa9-b34b-d9cf9bbf7e3c} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 2, line 2) (in query: SELECT bitXor(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019e591d3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019d59b31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:02.780441 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:02.795825 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019e591d3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019d59b31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:02.915289 [ 5380 ] {4d6bd6e5-a619-4c92-9585-ae01c9177899} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE t2; to attach existing table or CREATE TABLE t2
; to create new table or ATTACH TABLE t2 FROM '/path/to/data/'
; to create new table and attach data. 2025.07.13 02:35:03.006423 [ 5380 ] {4d6bd6e5-a619-4c92-9585-ae01c9177899} executeQuery: Code: 253. DB::Exception: There already is an active replica with this replica path /clickhouse/tables/OcbPpWLiOy/f7fd535d-442f-4881-9e25-cab7ed6e7833/replicas/r1. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42696) (comment: 03013_forbid_attach_table_if_active_replica_already_exists.sh) (query 1, line 1) (in query: attach table OcbPpWLiOy.t2 UUID 'f7fd535d-442f-4881-9e25-cab7ed6e7833' (a Int) engine=ReplicatedMergeTree('/clickhouse/tables/{database}/f7fd535d-442f-4881-9e25-cab7ed6e7833', '{replica}') order by tuple() SETTINGS index_granularity = 8192), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:485: 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&) @ 0x0000000030598bfa 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:35:03.092889 [ 5380 ] {} TCPHandler: Code: 253. DB::Exception: There already is an active replica with this replica path /clickhouse/tables/OcbPpWLiOy/f7fd535d-442f-4881-9e25-cab7ed6e7833/replicas/r1. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:485: 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&) @ 0x0000000030598bfa 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:35:03.120987 [ 5826 ] {87bdba3d-8e3c-406b-aa47-656f20f118cc} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 3, line 3) (in query: SELECT bitOr(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019681873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000195821d1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.130469 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019681873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000195821d1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.432952 [ 5826 ] {7380f498-71a8-4e13-a440-1e458c577258} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 4, line 4) (in query: SELECT bitTest(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.507287 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.584739 [ 5826 ] {fa691ef7-bcb7-4510-8646-8ddd92e81662} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 5, line 5) (in query: SELECT bitTest(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.591982 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.702084 [ 5826 ] {99622cd9-888f-4aa0-88a9-368df527aa47} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 6, line 6) (in query: SELECT bitRotateLeft(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000197bd293 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000196bbc31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.740698 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000197bd293 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000196bbc31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.942674 [ 5826 ] {0d1cfe35-5495-4d44-8d5d-3ccde00d6dfb} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 7, line 7) (in query: SELECT bitRotateRight(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000198f8df3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000197f7791 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:03.953168 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000198f8df3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000197f7791 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:04.043284 [ 5826 ] {cc235bfc-6d60-43a2-a47b-d81ea5560893} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 8, line 8) (in query: SELECT bitShiftLeft(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019a599f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019932df1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:04.066615 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019a599f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019932df1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:04.278327 [ 5826 ] {0c942024-5fae-47b9-b1ca-84b36c59779e} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01677_bit_float.sql) (query 9, line 9) (in query: SELECT bitShiftRight(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019bb96f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019a95491 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:04.302363 [ 5826 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019bb96f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019a95491 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:06.022322 [ 34277 ] {46b91c67-d5a5-40fd-b8da-d54a1add5b7b} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1046, line 349) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:06.031134 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:07.059107 [ 57039 ] {9f8bd986-a765-4d9b-886c-8bae2c5c059a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42636) (comment: 03143_asof_join_ddb_long.sql) (query 7, line 41) (in query: SELECT SUM(value), COUNT(*) FROM skewed_probe ASOF JOIN build USING (key, begin) ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 2025.07.13 02:35:07.097586 [ 57039 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222f37e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 27. ? @ 0x00007f9c53164ac3 28. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:07.232667 [ 3816 ] {183377dc-448f-4127-8e2b-21a5916689d7} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 256.43 MiB (attempt to allocate chunk of 0.00 B), maximum: 476.84 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42768) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (query 10, line 18) (in query: select key, groupArray(repeat('a', 200)), count() from data_01513 group by key format Null settings optimize_aggregation_in_order=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:35:07.281043 [ 3816 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 256.43 MiB (attempt to allocate chunk of 0.00 B), maximum: 476.84 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6b6a24 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6c7bce 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d94f04 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d8f22d 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:10.056291 [ 3815 ] {0b74364c-f6fd-496b-8fe0-6979e4b9030a} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 3) in function 'transform': In scope SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42752) (comment: 02542_transform_new.sql) (query 31, line 33) (in query: SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000020ce43f5 6. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c26027 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:10.067050 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 3) in function 'transform': In scope SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000020ce43f5 6. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c26027 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:10.109141 [ 3815 ] {78716771-7418-490f-8571-c6000c9fa797} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42752) (comment: 02542_transform_new.sql) (query 32, line 34) (in query: SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000020ce43f5 6. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c26027 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:10.112962 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000020ce43f5 6. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c26027 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:10.157811 [ 3815 ] {4a18b85e-c438-4641-b9cf-8d2e5f8aaf89} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42752) (comment: 02542_transform_new.sql) (query 33, line 35) (in query: SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000020ce43f5 6. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c26027 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:10.166016 [ 3815 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000020ce43f5 6. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020c26027 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:10.194291 [ 4142 ] {6d752c91-705e-436f-96a9-d058a502e2ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33340) (comment: 01508_partition_pruning_long_2.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_15`.`xMM` AS `__table1` WHERE `__table1`.`a` = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:10.219141 [ 4142 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:10.273548 [ 29256 ] {e2093da9-df8a-448d-a931-ad289cd11d10} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34716) (comment: 01508_partition_pruning_long_2.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from xMM where a = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:35:10.287263 [ 29256 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:10.797114 [ 29256 ] {ba466f47-deb5-4dec-8b50-547963c22b87} executeQuery: Code: 161. DB::Exception: Too many keys (65) are used for CubeTransform, the maximum is 63. (TOO_MANY_COLUMNS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34730) (comment: 03253_group_by_cube_too_many_keys.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT '' AS c0, '' AS c1, '' AS c2, '' AS c3, '' AS c4, '' AS c5, '' AS c6, '' AS c7, '' AS c8, '' AS c9, '' AS c10, '' AS c11, '' AS c12, '' AS c13, '' AS c14, '' AS c15, '' AS c16, '' AS c17, '' AS c18, '' AS c19, '' AS c20, '' AS c21, '' AS c22, '' AS c23, '' AS c24, '' AS c25, '' AS c26, '' AS c27, '' AS c28, '' AS c29, '' AS c30, '' AS c31, '' AS c32, '' AS c33, '' AS c34, '' AS c35, '' AS c36, '' AS c37, '' AS c38, '' AS c39, '' AS c40, '' AS c41, '' AS c42, '' AS c43, '' AS c44, '' AS c45, '' AS c46, '' AS c47, '' AS c48, '' AS c49, '' AS c50, '' AS c51, '' AS c52, '' AS c53, '' AS c54, '' AS c55, '' AS c56, '' AS c57, '' AS c58, '' AS c59, '' AS c60, '' AS c61, '' AS c62, '' AS c63, '' AS c64) GROUP BY ALL WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Processors/Transforms/CubeTransform.cpp:18: DB::CubeTransform::CubeTransform(DB::Block, std::shared_ptr, bool) @ 0x00000000320c703c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::CubeTransform* std::construct_at[abi:ne190107], bool&, DB::CubeTransform*>(DB::CubeTransform*, DB::Block const&, std::shared_ptr&&, bool&) @ 0x00000000320c6847 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool&, std::allocator, 0>(std::allocator, DB::Block const&, std::shared_ptr&&, bool&) @ 0x00000000320c645f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, std::shared_ptr, bool&, 0>(std::allocator const&, DB::Block const&, std::shared_ptr&&, bool&) @ 0x00000000320c62c6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320c5e48 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c37a51b 11. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c37a285 12. ./build_docker/./src/Processors/QueryPlan/CubeStep.cpp:70: DB::CubeStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320c5738 13. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211eaa0 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:35:10.810154 [ 29256 ] {} TCPHandler: Code: 161. DB::Exception: Too many keys (65) are used for CubeTransform, the maximum is 63. (TOO_MANY_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239783cf 5. ./build_docker/./src/Processors/Transforms/CubeTransform.cpp:18: DB::CubeTransform::CubeTransform(DB::Block, std::shared_ptr, bool) @ 0x00000000320c703c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::CubeTransform* std::construct_at[abi:ne190107], bool&, DB::CubeTransform*>(DB::CubeTransform*, DB::Block const&, std::shared_ptr&&, bool&) @ 0x00000000320c6847 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool&, std::allocator, 0>(std::allocator, DB::Block const&, std::shared_ptr&&, bool&) @ 0x00000000320c645f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, std::shared_ptr, bool&, 0>(std::allocator const&, DB::Block const&, std::shared_ptr&&, bool&) @ 0x00000000320c62c6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320c5e48 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c37a51b 11. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c37a285 12. ./build_docker/./src/Processors/QueryPlan/CubeStep.cpp:70: DB::CubeStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320c5738 13. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211eaa0 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:35:11.089299 [ 57925 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:11.507723 [ 5115 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:35:23: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:12.412191 [ 34277 ] {aacbabc3-f8eb-4f42-8f18-7ac7ab892ce7} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1073, line 358) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:12.429087 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:14.147012 [ 34277 ] {b1289de7-2251-40f9-be3e-7e9e04ce926d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=870). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1080, line 360) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:35:14.158425 [ 34277 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=870). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:35:14.468843 [ 34277 ] {629ff61b-ac1c-4316-8cdc-f6295a19fe66} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1082, line 361) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:14.478112 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:17.174883 [ 57042 ] {de14064a-ca39-421a-90c1-c5c12f961eaf} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34846) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x0000000018d45861 6. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000018d454df 7. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b011cc 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:17.188304 [ 57042 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x0000000018d45861 6. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000018d454df 7. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b011cc 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:17.441359 [ 57042 ] {12708940-a36a-45e4-b684-6bc59897a605} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34846) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000018d475cf 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000018d4567e 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b011cc 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:35:17.477710 [ 57042 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000018d475cf 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000018d4567e 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b011cc 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:35:17.560032 [ 34277 ] {1d18bfa9-3482-4bcf-bd2b-9e059fbedfad} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1094, line 365) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:17.572587 [ 5971 ] {8383be54-fb4a-447f-bc0a-d830d4e8be88} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fe68 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:17.579137 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:17.595053 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fe68 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:17.608663 [ 57042 ] {afd852d1-0753-4e56-a08e-ba2c5ef60459} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34846) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000018d475cf 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000018d4567e 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b011cc 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:35:17.671098 [ 57042 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000018d475cf 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000018d4567e 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b011cc 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cead4f 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:35:17.840833 [ 5971 ] {c44b8681-570c-4104-8f51-6125aaf49c77} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x0000000020f6cd6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fbd6 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:17.854117 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x0000000020f6cd6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fbd6 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.006491 [ 5971 ] {2e3530f3-dd27-48ac-ba99-84a2016c7ed5} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ee4a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:35:18.012688 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ee4a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:35:18.200426 [ 34277 ] {0ecdf140-e592-4d07-b795-dc55b811bdc7} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1097, line 366) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.278097 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.357798 [ 5971 ] {6b3448f8-4780-4c12-bf77-562c7dfc6b6d} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f7010a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.363008 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f7010a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.496161 [ 5971 ] {57787bd3-8a44-44ec-90da-1523bc018f37} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x0000000020f6cd6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fbd6 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.501526 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x0000000020f6cd6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fbd6 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.553974 [ 5971 ] {fc08a2ad-f00c-4657-b2ae-15d3cfb71498} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fe68 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.590876 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fe68 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.609968 [ 5105 ] {bccba532-8ca6-4d54-a8d9-a7a1413e1c24} executeQuery: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing CSVRowInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34910) (comment: 02681_group_array_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(CSV, 'entitypArray AggregateFunction(groupArray, String)', '295TMiews.viewNÿÿÿÿÿ""""""TabSeparÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿated d St"" r');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:404: DB::(anonymous namespace)::GroupArrayNodeBase::checkElementSize(unsigned long, unsigned long) @ 0x000000002469a996 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:421: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002469abd1 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000246f588c 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:192: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c543add 10. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 11. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 12. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 22. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 23. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 24. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:35:18.617787 [ 5105 ] {} TCPHandler: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing CSVRowInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:404: DB::(anonymous namespace)::GroupArrayNodeBase::checkElementSize(unsigned long, unsigned long) @ 0x000000002469a996 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:421: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002469abd1 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000246f588c 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c542dea 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:192: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c543add 10. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5f1f39 11. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319e4766 12. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031973911 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003190fba3 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000318486e4 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003180bad9 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003183f6b4 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183f89d 22. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285304ab 23. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3c046f 24. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d49139b 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc18155 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b22d 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 2025.07.13 02:35:18.772165 [ 5971 ] {13ec6652-1b37-4969-9f9f-d0095f1079fe} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fe68 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.788220 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f6fe68 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.928739 [ 5971 ] {31fa6916-235c-4af9-b73a-50be7942c192} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f7010a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:18.935670 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f7010a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.011665 [ 6126 ] {7ae43978-e9e2-4f87-a752-d4bf5944abb0} executeQuery: Code: 57. DB::Exception: Table test_11.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34928) (comment: 01356_wrong_filter-type_bug.sql) (query 2, line 3) (in query: CREATE TABLE t0 (`c0` String, `c1` Int32 CODEC(NONE), `c2` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 49608, min_bytes_for_wide_part = 928210069, 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 = 65411515, compact_parts_max_bytes_to_buffer = 37435405, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 19134234, merge_max_block_size = 1017, old_parts_lifetime = 233., prefer_fetch_merged_part_size_threshold = 4250616941, 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 = 11278995, 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 = 19403, primary_key_compress_block_size = 74952, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.046029 [ 6126 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.083431 [ 34260 ] {01eff713-f05b-4e92-aa5d-10b5315f7532} executeQuery: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48200) (comment: 03305_compressed_memory_eng_crash_reading_subcolumn.sql) (query 2, line 3) (in query: CREATE TABLE t0 (c0 Nullable(Int)) ENGINE = Memory() SETTINGS compress = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.096775 [ 34260 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.112068 [ 5971 ] {eaa6a178-2865-48a3-939c-cc7ea8ec5432} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000020f6cf6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f703c8 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.116299 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000020f6cf6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f703c8 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.214352 [ 5971 ] {27dbbf34-89b1-47d4-aa08-d283d312e3b8} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000020f6cf6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f703c8 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.238077 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000020f6cf6f 5. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020f703c8 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.459420 [ 5971 ] {4857cf88-9c5c-446f-95a6-4b5c1138a095} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x0000000020f68d8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ef4f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:35:19.471410 [ 34277 ] {93716c87-347d-4dda-8522-dd53a2d1922f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1103, line 368) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.485533 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x0000000020f68d8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ef4f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:35:19.579690 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:19.841219 [ 5971 ] {f2df3fff-ff03-4fb1-8cbf-75174f744050} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x0000000020f68e8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6e8b2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:35:19.871764 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x0000000020f68e8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6e8b2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:35:20.249419 [ 5971 ] {f187ccbe-0e8f-4408-883c-1e4585a1246d} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x0000000020f68d8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ef4f 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.265432 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x0000000020f68d8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ef4f 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.574646 [ 5971 ] {fcd311dd-2200-4ea2-b0ae-d8ab9b3e5175} 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.3.20372.altinityantalya (altinity build)) (from [::1]:34714) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x0000000020f68d8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ef4f 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.580754 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x0000000020f68d8f 5. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020f6ef4f 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.840843 [ 3766 ] {3873f3bd-4d44-4705-bd1a-b411cf0c7042} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48266) (comment: 02317_functions_with_nothing.sql) (query 1, line 1) (in query: SELECT JSONExtractKeysAndValuesRaw(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.845377 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.937655 [ 3766 ] {63c1d0fc-0e1d-4acf-babe-94c969ea4fa3} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48266) (comment: 02317_functions_with_nothing.sql) (query 2, line 2) (in query: SELECT JSONHas(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:20.943511 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.020986 [ 3766 ] {493d5147-34de-477c-9a2e-c78af01234d5} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48266) (comment: 02317_functions_with_nothing.sql) (query 3, line 3) (in query: SELECT isValidJSON(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.028484 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.190725 [ 3766 ] {3cd9d01d-fa19-4b68-9b12-8d46dbad7cc4} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48266) (comment: 02317_functions_with_nothing.sql) (query 4, line 4) (in query: SELECT concat(arrayJoin([]), arrayJoin([NULL, '']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.196645 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.255256 [ 3766 ] {44354730-a2a9-4327-b48a-dc0b0a810896} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48266) (comment: 02317_functions_with_nothing.sql) (query 5, line 5) (in query: SELECT plus(arrayJoin([]), arrayJoin([NULL, 1]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.258364 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.355689 [ 3766 ] {c2cbb79b-e9d7-4484-b445-d19cfd8d3753} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48266) (comment: 02317_functions_with_nothing.sql) (query 6, line 6) (in query: SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.384348 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5764: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc071ee 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:35:21.908393 [ 6126 ] {b080c6c2-ebfd-4b00-add4-bf4994d0e0ea} executeQuery: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48218) (comment: 02864_statistics_bug_67742.sql) (query 12, line 14) (in query: SELECT count(*) FROM tab WHERE a < '10.5';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0d0d28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b50d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc9e1f 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003211638f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd49d49 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd841aa 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a6ab 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 24. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 27. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 28. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:35:21.928219 [ 6126 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e263c4a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25f42d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0d0d28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b50d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc9e1f 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003211638f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd49d49 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd841aa 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd7a6ab 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x000000002dd6feb2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd700b9 24. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:718: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002f9d8a6c 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1083: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002ddae4d9 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9ffbb 27. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 28. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 2025.07.13 02:35:22.839064 [ 10341 ] {b60425cf-d6cf-405f-91e9-afa803bf970f} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_6n7me9sn.a INNER JOIN (SELECT b AS j, b AS bb FROM test_6n7me9sn.b) USING (j). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48298) (comment: 03107_ill_formed_select_in_materialized_view.sql) (query 7, line 12) (in query: CREATE MATERIALIZED VIEW view_4 ( bb UInt64, cnt UInt64) Engine=MergeTree ORDER BY bb POPULATE AS SELECT bb, count() AS cnt FROM (SELECT a, b AS j, b AS bb FROM a INNER JOIN (SELECT b AS j, b AS bb FROM b ) USING (j)) GROUP BY bb;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcebe46 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x000000002dc8f13a 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e1be 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:22.886705 [ 10341 ] {} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_6n7me9sn.a INNER JOIN (SELECT b AS j, b AS bb FROM test_6n7me9sn.b) USING (j). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc670ef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc61b99 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b241 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0fe5f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc5b209 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05068 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcebe46 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x000000002dc8f13a 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e1be 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:35:23.514518 [ 10341 ] {c43f1584-2001-4f39-ac94-597689b11ae5} executeQuery: Code: 60. DB::Exception: Table test_6n7me9sn.`.inner_id.2242ab70-91f3-4b6e-a746-8e1beee49d97` (b46e2213-3b3f-4404-b3dc-96e5a468fcc4) does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51648) (comment: 03107_ill_formed_select_in_materialized_view.sql) (in query: DROP DATABASE IF EXISTS test_6n7me9sn SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f5e72 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304deb2e 7. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304edcaf 8. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b315 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:35:23.522262 [ 10341 ] {c43f1584-2001-4f39-ac94-597689b11ae5} DynamicQueryHandler: Code: 60. DB::Exception: Table test_6n7me9sn.`.inner_id.2242ab70-91f3-4b6e-a746-8e1beee49d97` (b46e2213-3b3f-4404-b3dc-96e5a468fcc4) does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f5e72 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc332 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304deb2e 7. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304edcaf 8. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b315 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:26.079556 [ 34277 ] {ab39bbc4-d4c2-4f9a-8fb0-3eb7fbd7ab9f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1130, line 377) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:26.096165 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:26.593451 [ 6873 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:35:49: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:27.257061 [ 34277 ] {182ace24-cc1d-48c4-96ed-5aaf54a96001} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1136, line 379) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:27.277300 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:27.485081 [ 10341 ] {3ba2d745-4648-46a3-8579-124d15c3e112} executeQuery: Code: 57. DB::Exception: Table test_z7m2kofu.tp already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48438) (comment: 02968_projection_merge.sql) (query 11, line 31) (in query: CREATE TABLE tp (`type` Int32, `eventcnt` UInt64, `sign` Int8, PROJECTION p (SELECT type, sum(eventcnt) GROUP BY type)) ENGINE = CollapsingMergeTree(sign) ORDER BY type SETTINGS deduplicate_merge_projection_mode = 'rebuild', index_granularity = 35474, min_bytes_for_wide_part = 396902932, ratio_of_defaults_for_sparse_serialization = 0.12449303269386292, replace_long_file_name_to_hash = true, max_file_name_length = 83, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 376408280, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 30625673, merge_max_block_size = 21478, 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 = 10737418240, index_granularity_bytes = 7592218, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 95, 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 = 80085, primary_key_compress_block_size = 78654, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:27.502823 [ 10341 ] {} TCPHandler: Code: 57. DB::Exception: Table test_z7m2kofu.tp already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:28.330124 [ 46286 ] {6558e9c8-3c39-4954-ab20-c0db7b7906fd} executeQuery: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48544) (comment: 02958_transform_enum.sql) (query 2, line 2) (in query: WITH arrayJoin(['Hello', 'world'])::Enum('Hello', 'world') AS x SELECT x, transform(x, ['Hello', 'world', 'goodbye'], [123, 456], 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4d1f01 6. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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 @ 0x000000002afc524c 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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) @ 0x000000002afc4c86 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25ddae 14. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25d481 15. DB::(anonymous namespace)::FunctionTransform::initialize(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020c7340f 16. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038eff69b 17. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020c22aad 18. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 25. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 26. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 28. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 29. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 30. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 2025.07.13 02:35:28.344702 [ 46286 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04542f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4d1f01 6. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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 @ 0x000000002afc524c 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() 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) @ 0x000000002afc4c86 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad638f2 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc429 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acce847 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25ddae 14. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25d481 15. DB::(anonymous namespace)::FunctionTransform::initialize(std::vector> const&, std::shared_ptr const&) const @ 0x0000000020c7340f 16. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038eff69b 17. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020c22aad 18. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 25. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 26. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 28. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 29. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 30. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 2025.07.13 02:35:28.610196 [ 34277 ] {9ba86faa-b1c7-464f-8fa6-18686238eaf7} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1142, line 381) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:28.625293 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:32.692195 [ 34277 ] {4cb840d0-6fab-4be5-9a9f-3ce4661f61f7} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1160, line 387) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:32.695902 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:32.729936 [ 46286 ] {test_01948_tcp_test_11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60478) (comment: 01950_kill_large_group_by_query.sh) (query 1, line 1) (in query: SELECT * FROM ( SELECT a.name as n FROM ( SELECT 'Name' as name, number FROM system.numbers LIMIT 2000000 ) AS a, ( SELECT 'Name' as name2, number FROM system.numbers LIMIT 2000000 ) as b GROUP BY n ) LIMIT 20 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:35:32.774410 [ 46286 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:33.163543 [ 34277 ] {e6779c89-e440-4421-9537-f38fcc8cb1c1} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1163, line 388) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:33.167749 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:33.710651 [ 57044 ] {test_01948_http_test_11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60580) (comment: 01950_kill_large_group_by_query.sh) (in query: SELECT * FROM ( SELECT a.name as n FROM ( SELECT 'Name' as name, number FROM system.numbers LIMIT 2000000 ) AS a, ( SELECT 'Name' as name2, number FROM system.numbers LIMIT 2000000 ) as b GROUP BY n ) LIMIT 20 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:35:33.728325 [ 57044 ] {test_01948_http_test_11} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002def382f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002def3746 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f17 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b4641 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:36.217054 [ 5380 ] {f5781eb2-8272-447e-9b57-902a20f88802} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalNanosecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalNanosecond(1) < toIntervalMonth(2). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 22, line 24) (in query: SELECT INTERVAL 1 NANOSECOND < INTERVAL 2 MONTH;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:36.225883 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalNanosecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalNanosecond(1) < toIntervalMonth(2). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:36.225900 [ 34277 ] {04dfd613-e4e2-437a-9d9e-f41a282dfe7a} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1181, line 394) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:36.246633 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:37.349348 [ 57044 ] {ee45a11a-e582-4565-b74d-428b788fc323} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60580) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (query 14, line 26) (in query: INSERT INTO quorum2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x0000000031178a93 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003119bc34 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003119b7f8 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000031176164 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003115fb50 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031174fa1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc48c1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:35:37.354930 [ 57044 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x0000000031178a93 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003119bc34 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003119b7f8 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000031176164 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003115fb50 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031174fa1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc48c1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:35:37.969777 [ 5476 ] {818d811c-5045-4242-8476-09a1ed0f8172} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 20.00 million, current rows: 18.45 quintillion: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:42870) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (query 15, line 28) (in query: SELECT `__table1`.`x` AS `x` FROM `test_11`.`quorum1` AS `__table1` ORDER BY `__table1`.`x` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:35:37.983283 [ 5476 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 20.00 million, current rows: 18.45 quintillion: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:38.023693 [ 46294 ] {5033de27-a2ec-49d7-805a-673f5ac6d0e8} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 20.00 million, current rows: 18.45 quintillion: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33488) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (query 15, line 28) (in query: SELECT `__table1`.`x` AS `x` FROM `test_11`.`quorum1` AS `__table1` ORDER BY `__table1`.`x` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:35:38.030099 [ 57044 ] {027711c5-feb5-41cd-b24d-19e5c80a2a10} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 20.00 million, current rows: 18.45 quintillion: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60580) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (query 15, line 28) (in query: SELECT x FROM quorum1 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:35:38.030512 [ 46294 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 20.00 million, current rows: 18.45 quintillion: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:38.043834 [ 57044 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 20.00 million, current rows: 18.45 quintillion: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:39.018247 [ 5380 ] {4f13c565-fad9-4b82-8b30-5f9e1eb8a091} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMicrosecond and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMicrosecond(36000000000000) < toIntervalQuarter(1). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 38, line 43) (in query: SELECT INTERVAL 36000000000000 MICROSECOND < INTERVAL 1 QUARTER;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:39.026096 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMicrosecond and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMicrosecond(36000000000000) < toIntervalQuarter(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:39.999799 [ 6024 ] {1fada3ec-9126-42dc-8d78-789c437f889d} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 22.00: While executing Remote. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60758) (comment: 01583_const_column_in_set_index.sql) (query 5, line 7) (in query: select * from insub where i in (select toInt32(3) from numbers(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.013721 [ 6024 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 22.00: While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3bbdfb 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838da4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.054759 [ 6951 ] {c612394b-8c37-453e-8a1a-dee8c694dc9c} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:37282): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37282) (comment: 01583_const_column_in_set_index.sql) (query 5, line 7) (in query: SELECT `__table1`.`i` AS `i`, `__table1`.`j` AS `j` FROM `test_11`.`insub` AS `__table1` WHERE `__table1`.`i` IN (SELECT _CAST(3, 'Int32') AS `toInt32(3)` FROM numbers(10) AS `__table1`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:654: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x00000000316df753 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f8ae32 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f85802 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:152: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221de7c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.059108 [ 6951 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:37282): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:654: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x00000000316df753 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f8ae32 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f85802 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:152: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221de7c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.277996 [ 34277 ] {a6dc58f0-6c7f-4085-b57e-78fd3948523d} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1199, line 400) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.370235 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.799010 [ 4142 ] {de5dde6c-955d-410a-a687-e83b8d56e277} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51580) (comment: 03172_dynamic_binary_serialization.sh) (query 1, line 1) (in query: insert into test select 9, materialize(42)::UInt128), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:40.824197 [ 4142 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:35:41.173567 [ 5380 ] {50b7e402-f3b2-4844-983d-8e66ccae10db} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMillisecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalMillisecond(36000000000000) < toIntervalYear(1). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 52, line 60) (in query: SELECT INTERVAL 36000000000000 MILLISECOND < INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:41.189778 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMillisecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalMillisecond(36000000000000) < toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:42.689778 [ 3815 ] {93dbc2e9-d65a-456e-b7c2-121c8e23978f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_without_merge (d5e5253d-c6c7-43ca-9572-3dbacdef80d4)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51618) (comment: 02676_optimize_old_parts_replicated.sh) (query 6, line 9) (in query: INSERT INTO test_without_merge SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d56 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:35:42.707955 [ 3815 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_without_merge (d5e5253d-c6c7-43ca-9572-3dbacdef80d4)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d56 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:35:42.735019 [ 5380 ] {3ed19d95-5466-4dfd-ae6e-58012d81fc28} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(36000000000000) < toIntervalMonth(1). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 64, line 75) (in query: SELECT INTERVAL 36000000000000 SECOND < INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:42.738432 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(36000000000000) < toIntervalMonth(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:44.391231 [ 5380 ] {5dba2093-d362-4cea-8233-337ab26b6134} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMinute and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMinute(2) = toIntervalQuarter(120). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 74, line 88) (in query: SELECT INTERVAL 2 MINUTE = INTERVAL 120 QUARTER;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:44.400971 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMinute and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMinute(2) = toIntervalQuarter(120). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:44.593872 [ 34277 ] {b96ec621-fc4f-429f-93fc-0973b4dd1c4f} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1220, line 407) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:44.630085 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:45.929333 [ 5380 ] {0cb9ba89-c5a0-48aa-99bd-6c9a9ff0da21} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalHour and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalHour(2) < toIntervalYear(1). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 82, line 99) (in query: SELECT INTERVAL 2 HOUR < INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:45.949414 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalHour and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalHour(2) < toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d2eb6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b5a90 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:46.855233 [ 34277 ] {bb1bad0a-5ec8-4716-b2cd-d5d6578d77f1} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1229, line 410) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:46.870414 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:46.930576 [ 5380 ] {5115f6d0-b2e0-4be0-88b9-180ee44be80e} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalDay and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalDay(2) = toIntervalMonth(48). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 88, line 108) (in query: SELECT INTERVAL 2 DAY = INTERVAL 48 MONTH;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:46.967582 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalDay and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalDay(2) = toIntervalMonth(48). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:47.676578 [ 5380 ] {7e168103-36af-4dd3-8726-8cf0e0ffcb1c} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalWeek and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalWeek(124) > toIntervalQuarter(8). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 92, line 115) (in query: SELECT INTERVAL 124 WEEK > INTERVAL 8 QUARTER;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001b0201d6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b002db0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:47.690714 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalWeek and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalWeek(124) > toIntervalQuarter(8). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001b0201d6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b002db0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:49.143290 [ 5380 ] {e1bbeb8f-3dad-4b50-b823-b01041073ae4} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMonth and IntervalMicrosecond because the number of days in a month is not fixed: In scope SELECT toIntervalMonth(6) = toIntervalMicrosecond(26). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 100, line 126) (in query: SELECT INTERVAL 6 MONTH = INTERVAL 26 MICROSECOND;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:49.147843 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMonth and IntervalMicrosecond because the number of days in a month is not fixed: In scope SELECT toIntervalMonth(6) = toIntervalMicrosecond(26). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:49.578086 [ 4142 ] {933349ac-609f-4c34-9558-7bcf9be6d391} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48582) (comment: 01273_arrow_dictionaries_load.sh) (query 1, line 1) (in query: SELECT * FROM arrow_dicts), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:49.601161 [ 4142 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=852). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:49.848151 [ 33006 ] {3e507f80-13f9-4c79-b60e-21d9612eac7d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/data.bin (position: 484, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: da72210b720d8009e14a89ef380ffe63820c00000002000000): (while reading column value1): (while reading from part /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/ in table test_15.t (84dee4b2-96bc-4cd0-b11a-8f5023649d75) located on disk default of type local, from mark 5 with max_rows_to_read = 9): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:32784) (comment: 02920_rename_column_of_skip_indices.sql) (query 7, line 20) (in query: SELECT `__table1`.`key1` AS `key1`, `__table1`.`value11` AS `value11`, `__table1`.`value2` AS `value2` FROM `test_15`.`t` AS `__table1` WHERE `__table1`.`value11` = '000'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c67cc12 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 2025.07.13 02:35:49.862662 [ 33006 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/data.bin (position: 484, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: da72210b720d8009e14a89ef380ffe63820c00000002000000): (while reading column value1): (while reading from part /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/ in table test_15.t (84dee4b2-96bc-4cd0-b11a-8f5023649d75) located on disk default of type local, from mark 5 with max_rows_to_read = 9): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c67cc12 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:49.922413 [ 5732 ] {c4d1bd42-8ab4-461f-98b6-fb80952794e6} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/data.bin (position: 484, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: da72210b720d8009e14a89ef380ffe63820c00000002000000): (while reading column value1): (while reading from part /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/ in table test_15.t (84dee4b2-96bc-4cd0-b11a-8f5023649d75) located on disk default of type local, from mark 5 with max_rows_to_read = 9): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c67cc12 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51928) (comment: 02920_rename_column_of_skip_indices.sql) (query 7, line 20) (in query: -- Index works without mutation applied. SELECT * FROM t WHERE value11 = '000' SETTINGS max_rows_to_read = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:35:49.984227 [ 5732 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/data.bin (position: 484, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: da72210b720d8009e14a89ef380ffe63820c00000002000000): (while reading column value1): (while reading from part /var/lib/clickhouse/store/84d/84dee4b2-96bc-4cd0-b11a-8f5023649d75/all_1_1_0/ in table test_15.t (84dee4b2-96bc-4cd0-b11a-8f5023649d75) located on disk default of type local, from mark 5 with max_rows_to_read = 9): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032dac4c8 15. DB::ReadBuffer::next() @ 0x0000000017e75832 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c67cc12 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f347f4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f569b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c93f1 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:35:50.018691 [ 5380 ] {2159ac1b-4bef-45c7-ba1a-74258224e437} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalQuarter and IntervalNanosecond because the number of days in a month is not fixed: In scope SELECT toIntervalQuarter(2) = toIntervalNanosecond(6). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 106, line 135) (in query: SELECT INTERVAL 2 QUARTER = INTERVAL 6 NANOSECOND;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:50.021684 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalQuarter and IntervalNanosecond because the number of days in a month is not fixed: In scope SELECT toIntervalQuarter(2) = toIntervalNanosecond(6). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:50.219828 [ 3863 ] {0713a54c-3261-4219-8694-37aa25b1183f} executeQuery: Code: 57. DB::Exception: Table test_cvyaif3b.comment_test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48622) (comment: 02020_alter_table_modify_comment.sh) (query 2, line 3) (in query: CREATE TABLE comment_test_table ( k UInt64, s String ) ENGINE = MergeTree() ORDER BY k COMMENT 'Test table with comment';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:50.258685 [ 3863 ] {} TCPHandler: Code: 57. DB::Exception: Table test_cvyaif3b.comment_test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:50.542985 [ 5380 ] {47f83633-81d6-4930-854c-8d78a00bbf40} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalYear and IntervalSecond because the number of days in a month is not fixed: In scope SELECT toIntervalYear(2) = toIntervalSecond(8). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60560) (comment: 03223_interval_data_type_comparison.sql) (query 110, line 142) (in query: SELECT INTERVAL 2 YEAR = INTERVAL 8 SECOND;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:50.552137 [ 5380 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalYear and IntervalSecond because the number of days in a month is not fixed: In scope SELECT toIntervalYear(2) = toIntervalSecond(8). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000002c51fef4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c523fed 7. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7010b6 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e3bd0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:35:50.762544 [ 32979 ] {e757b6e6-3914-447b-a112-edb1efd4f5d9} executeQuery: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48664) (comment: 01462_test_codec_on_alias.sql) (query 3, line 5) (in query: CREATE TABLE compression_codec_on_alias (`c0` ALIAS c1 CODEC(ZSTD), `c1` UInt64) ENGINE = MergeTree PARTITION BY c0 ORDER BY c1 SETTINGS index_granularity = 42594, min_bytes_for_wide_part = 181406775, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 106, min_bytes_for_full_part_storage = 407170479, compact_parts_max_bytes_to_buffer = 360915914, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 27868592, merge_max_block_size = 8843, old_parts_lifetime = 56., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 905209, vertical_merge_algorithm_min_columns_to_activate = 30, min_merge_bytes_to_use_direct_io = 6085527315, index_granularity_bytes = 14708040, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 29, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 10248, primary_key_compress_block_size = 99916, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:705: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc686c6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:35:50.768428 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:705: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc686c6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:35:51.584014 [ 32979 ] {3a571723-7477-4180-8770-30b7ebad462a} executeQuery: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48664) (comment: 01462_test_codec_on_alias.sql) (query 7, line 19) (in query: ALTER TABLE compression_codec_on_alias ADD COLUMN `c3` ALIAS c2 CODEC(ZSTD) AFTER c2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:134: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x00000000302c3d7d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:158: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4be92 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:51.601239 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/AlterCommands.cpp:134: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x00000000302c3d7d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:158: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4be92 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:51.709814 [ 6940 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:36:10: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:52.073558 [ 57041 ] {5ba8f4ba-4f23-4acc-a83e-2aaed6c2533b} executeQuery: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48748) (comment: 02017_create_distributed_table_coredump.sql) (query 5, line 7) (in query: CREATE TABLE t (`val` UInt32) ENGINE = MergeTree ORDER BY val SETTINGS index_granularity = 57405, 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 = 35729977, compact_parts_max_bytes_to_buffer = 164518279, compact_parts_max_granules_to_buffer = 20, compact_parts_merge_max_bytes_to_prefetch_part = 17542463, merge_max_block_size = 23129, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 749649, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 26558928, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 86887, primary_key_compress_block_size = 52924, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:52.173570 [ 57041 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:53.425731 [ 34340 ] {db0f12b7-7ecc-4b4c-bd1a-1cd55f04a53a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 5, line 6) (in query: SELECT dateTimeToSnowflakeID();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:53.441111 [ 34340 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:53.891011 [ 34340 ] {1ebf7a17-3311-4f37-863b-5d066a784d56} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 6, line 7) (in query: SELECT dateTime64ToSnowflakeID();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:53.905121 [ 34340 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.055234 [ 34340 ] {5e48382f-70b7-421a-8b8c-cfa96f729a31} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflakeID('invalid_dt'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 7, line 8) (in query: SELECT dateTimeToSnowflakeID('invalid_dt');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:54.059486 [ 34340 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflakeID('invalid_dt'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:54.155546 [ 34340 ] {b52d1e54-9c7a-47d8-ba94-e8078c4fd6ec} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflakeID('invalid_dt'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 8, line 9) (in query: SELECT dateTime64ToSnowflakeID('invalid_dt');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:54.159740 [ 34340 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflakeID('invalid_dt'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002acecd86 7. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:35:54.270350 [ 34340 ] {2b54f99c-3c3a-4df4-9e98-3fea99e16a3b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'dateTimeToSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT dateTimeToSnowflakeID(now(), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 9, line 10) (in query: SELECT dateTimeToSnowflakeID(now(), 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.289233 [ 34340 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'dateTimeToSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT dateTimeToSnowflakeID(now(), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.488363 [ 34340 ] {dfb9e2ac-d18e-4dd5-b143-ad5a85e1b27c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'dateTime64ToSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT dateTime64ToSnowflakeID(now64(), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 10, line 11) (in query: SELECT dateTime64ToSnowflakeID(now64(), 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.503055 [ 34340 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'dateTime64ToSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT dateTime64ToSnowflakeID(now64(), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. 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&&) @ 0x000000002acf0b17 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002aced51a 6. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.563665 [ 34340 ] {333f249d-d94f-47f9-9391-a44bc23886b2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID(now(), 42, 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 11, line 12) (in query: SELECT dateTimeToSnowflakeID(now(), 42, 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.567996 [ 34340 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID(now(), 42, 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTimeToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05438a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.603465 [ 34340 ] {8c89134f-a8e8-4e38-8849-88e10c2c69e6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID(now64(), 42, 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48818) (comment: 01942_dateTimeToSnowflakeID.sql) (query 12, line 13) (in query: SELECT dateTime64ToSnowflakeID(now64(), 42, 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.628047 [ 34340 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID(now64(), 42, 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002acf02af 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002aced0bf 6. DB::FunctionDateTime64ToSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a05562a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.902623 [ 57042 ] {b7ea587d-79c2-410d-bfa8-393e60d16289} executeQuery: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48932) (comment: 03006_join_on_inequal_expression_2.gen.sql) (query 4, line 11) (in query: CREATE TABLE t2 (`key` UInt32, `a` UInt32, `attr` String) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 28762, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 105, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 257061352, compact_parts_max_granules_to_buffer = 40, compact_parts_merge_max_bytes_to_prefetch_part = 20374191, merge_max_block_size = 3680, old_parts_lifetime = 115., 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 = 7230473855, index_granularity_bytes = 15801322, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 9431, primary_key_compress_block_size = 28196, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:54.936081 [ 57042 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:55.249893 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:56.126219 [ 34277 ] {66d8da8c-fa56-423b-acdb-799176863784} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1271, line 424) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:56.139965 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:57.849162 [ 4468 ] {} InterserverIOHTTPHandler: Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:/clickhouse/tables/01-01/visits/replicas/some.server.com. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./src/Interpreters/InterserverIOHandler.h:74: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x00000000315e986a 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:66: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x00000000315e5908 7. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315e6a3b 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:35:58.122207 [ 34260 ] {b88d07d5-959e-44e4-aa81-3f729d8b867a} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_without_merge (d5e5253d-c6c7-43ca-9572-3dbacdef80d4)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:49178) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 2) (in query: DROP TABLE test_without_merge;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:35:58.137608 [ 34260 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_without_merge (d5e5253d-c6c7-43ca-9572-3dbacdef80d4)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:35:59.862607 [ 34277 ] {cbd96591-a5e9-49f8-9511-979f6b1b38d2} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1289, line 430) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:35:59.868602 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:00.190651 [ 10341 ] {38de3f7b-b6ba-45c6-946d-1f0f43f8ea13} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56972) (comment: 03172_dynamic_binary_serialization.sh) (query 1, line 1) (in query: insert into test select 44, materialize([tuple(1, 2), tuple(3, 4)])::Nested(a UInt32, b UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:00.223259 [ 10341 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003182195b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:36:00.260028 [ 34277 ] {56596058-bd8c-45d7-8ad5-bf1330ec814e} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1292, line 431) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:00.292937 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.768867 [ 4938 ] {2c0eb020-8303-48ee-88c1-a5d7cb7693a1} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39022) (comment: 01710_force_use_projection.sql) (query 7, line 13) (in query: SELECT sum(`__table1`.`eventcnt`) AS `eventcnt`, `__table1`.`d1` AS `d1` FROM `test_15`.`tp` AS `__table1` GROUP BY `__table1`.`d1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.775994 [ 4938 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.800159 [ 5971 ] {36f778b0-3fb4-45e1-b17d-872bbc1c323e} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59018) (comment: 01710_force_use_projection.sql) (query 7, line 13) (in query: SELECT sum(`__table1`.`eventcnt`) AS `eventcnt`, `__table1`.`d1` AS `d1` FROM `test_15`.`tp` AS `__table1` GROUP BY `__table1`.`d1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.809077 [ 5971 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.854342 [ 46286 ] {82d7dd80-a4d4-47d5-b73a-fd03d7132e7b} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40428) (comment: 01710_force_use_projection.sql) (query 7, line 13) (in query: SELECT sum(`__table1`.`eventcnt`) AS `eventcnt`, `__table1`.`d1` AS `d1` FROM `test_15`.`tp` AS `__table1` GROUP BY `__table1`.`d1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.866757 [ 46286 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.950368 [ 34260 ] {5159182b-aa2f-4c8c-b4cd-4ca0834effdb} executeQuery: Code: 584. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (PROJECTION_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56990) (comment: 01710_force_use_projection.sql) (query 7, line 13) (in query: select sum(eventcnt) eventcnt, d1 from tp group by d1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:36:01.970877 [ 34260 ] {} TCPHandler: Code: 584. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228aadd 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003150a218 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3f9da5 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:01.998004 [ 34277 ] {4a972a8b-79c4-450f-af0f-e3c5c72e3164} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1301, line 434) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:02.014768 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:02.363172 [ 34277 ] {b3884cfb-75f4-4919-b557-c7b5c3985dd4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1304, line 435) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:02.373546 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:03.939030 [ 57044 ] {cd0a7342-a326-4f7f-9218-dc13e3cea54c} executeQuery: Code: 57. DB::Exception: Table test_cvyaif3b.comment_test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57152) (comment: 02020_alter_table_modify_comment.sh) (query 2, line 3) (in query: CREATE TABLE comment_test_table ( k UInt64, s String ) ENGINE = TinyLog COMMENT 'Test table with comment';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:03.955987 [ 57044 ] {} TCPHandler: Code: 57. DB::Exception: Table test_cvyaif3b.comment_test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:04.748397 [ 34277 ] {f8d2f43d-87d5-45d0-a4ec-8cbad0ff714d} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1313, line 438) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:04.754154 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:05.507684 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:05.509992 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:36:05.522347 [ 2824 ] {15df6f5b-271a-47c9-af97-8a88126fd5d1} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57194) (comment: 00217_shard_global_subquery_columns_with_same_name.sql) (query 2, line 5) (in query: SELECT k, a FROM (SELECT 42 AS k FROM remote('127.0.0.2', system.one)) GLOBAL ALL FULL OUTER JOIN (SELECT 42 AS k, 1 AS a, a) USING k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:36:05.603093 [ 2824 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:05.940411 [ 3816 ] {8d4418ec-d219-4e4e-a09a-a83e1c33abd7} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 489.00 MiB (attempt to allocate chunk of 16.25 MiB bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42768) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (query 12, line 20) (in query: -- for WITH TOTALS previous groups should be kept. select key, groupArray(repeat('a', 200)), count() from data_01513 group by key with totals format Null settings optimize_aggregation_in_order=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::ColumnString::insertData(char const*, unsigned long) @ 0x0000000017d06bd3 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:448: DB::(anonymous namespace)::GroupArrayGeneralImpl>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x00000000246f61a6 13. ./build_docker/./src/Columns/ColumnAggregateFunction.cpp:180: DB::ColumnAggregateFunction::convertToValues(COW::mutable_ptr) @ 0x000000002fa1e147 14. ./build_docker/./src/Processors/Transforms/finalizeChunk.cpp:28: DB::finalizeChunk(DB::Chunk&, std::vector> const&) @ 0x0000000031f16152 15. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:170: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x0000000031eb9fbf 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:36:05.974347 [ 3816 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 489.00 MiB (attempt to allocate chunk of 16.25 MiB bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab68e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239920e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc92e6 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc7ea7 11. DB::ColumnString::insertData(char const*, unsigned long) @ 0x0000000017d06bd3 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:448: DB::(anonymous namespace)::GroupArrayGeneralImpl>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x00000000246f61a6 13. ./build_docker/./src/Columns/ColumnAggregateFunction.cpp:180: DB::ColumnAggregateFunction::convertToValues(COW::mutable_ptr) @ 0x000000002fa1e147 14. ./build_docker/./src/Processors/Transforms/finalizeChunk.cpp:28: DB::finalizeChunk(DB::Chunk&, std::vector> const&) @ 0x0000000031f16152 15. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:170: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x0000000031eb9fbf 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:07.830628 [ 5826 ] {a7604c01-5e14-477b-875e-603cb0bd6640} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47778) (comment: 03143_asof_join_ddb_long.sql) (in query: DROP DATABASE IF EXISTS test_z9chio3p SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:36:07.832267 [ 5826 ] {a7604c01-5e14-477b-875e-603cb0bd6640} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:08.683292 [ 34277 ] {8a07094c-240c-4c96-aadf-7fcf66457a77} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1325, line 442) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:08.691872 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.040947 [ 57044 ] {2e2c75af-4489-491f-9e66-dea9f2ff0cce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39836) (comment: 01035_prewhere_with_alias.sql) (query 2, line 2) (in query: CREATE TABLE test (`a` UInt8, `b` UInt8, `c` UInt16 ALIAS a + b) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 40794, min_bytes_for_wide_part = 741588538, 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 = 531998103, compact_parts_max_granules_to_buffer = 159, compact_parts_merge_max_bytes_to_prefetch_part = 22492498, merge_max_block_size = 23689, 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 = 85, min_merge_bytes_to_use_direct_io = 9614006383, index_granularity_bytes = 14050799, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 29, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 16727, primary_key_compress_block_size = 40771, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.058983 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.197152 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.198150 [ 57039 ] {1f364f49-3255-4f1a-a5a6-dfa9278822b1} executeQuery: Code: 452. DB::Exception: Received from localhost:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39812) (comment: 02287_legacy_column_name_of_tuple_literal_over_distributed.sql) (query 3, line 4) (in query: select if(in(dummy, tuple(0, 1)), 'ok', 'ok') from remote('localhost', system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:36:10.211894 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.213861 [ 57039 ] {} TCPHandler: Code: 452. DB::Exception: Received from localhost:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.584506 [ 6951 ] {889cabe1-64ba-41ce-94a1-bbc7b1c00965} PushingToViews: Failed to push block to view test_3.mv_table (59378434-321b-470e-8306-526d45e07a2d), ReplicatedMergeTree (table test_3.`.inner_id.59378434-321b-470e-8306-526d45e07a2d` (16c0e7a7-83b9-43dc-bbb7-7bf3cf9ed4db)) does not support transactions 2025.07.13 02:36:10.778815 [ 6951 ] {889cabe1-64ba-41ce-94a1-bbc7b1c00965} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3.`.inner_id.59378434-321b-470e-8306-526d45e07a2d` (16c0e7a7-83b9-43dc-bbb7-7bf3cf9ed4db)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39764) (comment: 03167_transactions_are_really_disabled.sql) (query 7, line 10) (in query: INSERT INTO null_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:328: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x000000002dce7b45 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031efaaff 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:10.858142 [ 6951 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3.`.inner_id.59378434-321b-470e-8306-526d45e07a2d` (16c0e7a7-83b9-43dc-bbb7-7bf3cf9ed4db)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:328: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x000000002dce7b45 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031efaaff 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dceef5d 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14a9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.037682 [ 57039 ] {3d27fe83-b96b-49d7-bea0-76cb2574f1ac} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39920) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.064289 [ 57039 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.312894 [ 57044 ] {120ac582-ea66-45d7-aa97-39c19fb2d267} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39936) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.333966 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.534761 [ 5382 ] {fe48c724-e34d-4e32-84c5-7d704abf3c2f} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39958) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.554119 [ 57044 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:11.560207 [ 57044 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:11.562022 [ 5382 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.763008 [ 3766 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:11.783765 [ 3766 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:11.803211 [ 6917 ] {} ExternalDictionariesLoader: Could not update external dictionary '6f971cab-4a7a-4afe-a78a-b1dc4ca9177c', leaving the previous version, next update is scheduled at 2025-07-13 02:37:27: Code: 60. DB::Exception: Unknown table expression identifier 'test_adhu7tze.complex_key_simple_attributes_source_table' in scope SELECT id, id_key, value_first, value_second FROM test_adhu7tze.complex_key_simple_attributes_source_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::loadData() @ 0x0000000028aca975 20. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000028ac9e6e 21. std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c945 22. std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr const&) @ 0x0000000028c0c722 23. DB::HashedArrayDictionary<(DB::DictionaryKeyType)1, false>::clone() const @ 0x0000000028acd017 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:11.920969 [ 5382 ] {18591e2a-8416-45ff-ab47-7a3944080cc5} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40016) (comment: 02126_fix_filelog.sh) (query 1, line 1) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:11.940103 [ 5382 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:13.682782 [ 33006 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:13.683298 [ 33006 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:13.887145 [ 3815 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:13.887956 [ 3815 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.108387 [ 5380 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.109065 [ 5380 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.350982 [ 5380 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.352220 [ 5380 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.612899 [ 46296 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.613859 [ 46296 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.841379 [ 46285 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:14.842040 [ 46285 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:15.348646 [ 46285 ] {f5f5cc42-2a5c-487b-b753-b43863d01a0d} executeQuery: Code: 46. DB::Exception: Function with name `plu` does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40438) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT plu(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:15.369583 [ 46285 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `plu` does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:15.904299 [ 7056 ] {7d9321a4-4685-4bd7-a471-73dc4400a679} executeQuery: Code: 46. DB::Exception: Function with name `uniqExac` does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40502) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:15.920764 [ 7056 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqExac` does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:17.337535 [ 5826 ] {7c164119-7ceb-4cf1-87df-36cd5980413e} executeQuery: Code: 46. DB::Exception: Function with name `test_user_defined_function_test_3A` does not exist. In scope SELECT test_user_defined_function_test_3A(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_3']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40720) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT test_user_defined_function_test_3A(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:17.364843 [ 5826 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `test_user_defined_function_test_3A` does not exist. In scope SELECT test_user_defined_function_test_3A(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_3']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:18.226243 [ 4938 ] {a3f78b23-4eea-48f8-8576-2a6181e87578} executeQuery: Code: 46. DB::Exception: Function with name `lambda_functio` does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40872) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: WITH (x -> x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:18.251185 [ 4938 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `lambda_functio` does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4143f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:18.791214 [ 5826 ] {e67bf5ce-ee49-4a36-bb83-7a02e5460ac1} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40934) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000028d689cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3fcbb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:18.825073 [ 5826 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000028d689cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3fcbb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:18.948817 [ 4938 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:18.949838 [ 4938 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:19.174899 [ 6951 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:19.176976 [ 6951 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:19.233575 [ 34277 ] {e329dd81-e0aa-4064-ba09-777ba2b25c05} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1367, line 456) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:19.237654 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:19.616926 [ 34277 ] {3ba77c40-8d9f-43a8-86e9-e50ea9cde19a} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1370, line 457) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:19.625710 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:21.164125 [ 6126 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.164760 [ 6126 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.397317 [ 3766 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.397959 [ 3766 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.485860 [ 57044 ] {95c98fdd-1148-41ac-8793-8fd0089a45e2} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45604) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:21.516903 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:21.649178 [ 6126 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.650492 [ 6126 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.884981 [ 3766 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:21.888872 [ 3766 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_hzu5svdq: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce789 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:22.039636 [ 6126 ] {63d34653-dbd5-4bd5-9923-74769765adc8} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45646) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a801ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:22.054195 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a801ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:22.100114 [ 5380 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:22.101687 [ 5380 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:22.341362 [ 57039 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:22.342014 [ 57039 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_hzu5svdq` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_hzu5svdq`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002bdbc9b7 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdbc787 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdbbc01 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdba792 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdba71b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcce084 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df34000 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df33875 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316ba71b 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316aa9be 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:22.555971 [ 6126 ] {9b4f3dd6-78b7-4f9b-a8d4-441804a30f55} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45756) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x0000000020a8102f 5. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020a7e3ea 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:22.580212 [ 6126 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x0000000020a8102f 5. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020a7e3ea 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:23.041047 [ 5476 ] {84e91232-9dbc-486e-beba-62ee8fcac66a} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45830) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020a7e851 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:23.083984 [ 5476 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020a7e851 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:23.476059 [ 33006 ] {5b99ede2-fe47-44dd-ba19-1169d7c0e9a8} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45898) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:23.492526 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:23.862382 [ 3863 ] {42b90cfb-d0cf-4443-91c9-026177d26a15} 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.3.20372.altinityantalya (altinity build)) (from [::1]:45968) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:23.882984 [ 3863 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.308812 [ 46296 ] {dadf0fda-5035-4ca3-a92f-320387d92d6f} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46024) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.349445 [ 46296 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.701068 [ 57039 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.708027 [ 57039 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.800580 [ 3766 ] {17f5b315-7af0-4a5e-afce-a93276a6abe2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAny: In scope SELECT multiSearchAny(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45708) (comment: 02294_stringsearch_with_nonconst_needle.sql) (query 16, line 43) (in query: select multiSearchAny(materialize('Hello World'), materialize([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f037137 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.824023 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAny: In scope SELECT multiSearchAny(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f037137 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.824486 [ 32979 ] {1ee3da8c-cdb7-48bc-9bf4-e8a5f73e3573} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46060) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:24.844076 [ 32979 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.330886 [ 3863 ] {199a9e3d-1cba-444e-b24a-ba7aef11ed1a} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46100) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.345193 [ 3863 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.689048 [ 46296 ] {be115a7c-12c7-41db-b4a6-f86794815bdd} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46162) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.702812 [ 46296 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.828753 [ 34340 ] {7c9da025-445e-4133-a6e8-ce4bb9856be9} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46176) (comment: 02125_fix_storage_filelog.sql) (query 1, line 1) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.838826 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.975364 [ 34340 ] {00b5e295-25e3-4ae0-a012-25e549ecf285} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46176) (comment: 02125_fix_storage_filelog.sql) (query 2, line 2) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:25.980230 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.058425 [ 34340 ] {282f1f15-8439-4934-ab1c-dface2e1a8e9} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46176) (comment: 02125_fix_storage_filelog.sql) (query 3, line 3) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.085005 [ 34340 ] {} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:195: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x00000000308b1069 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf773 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x00000000308cf52e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308c5b26 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.172533 [ 6951 ] {08fa9e50-f355-4869-b57e-3cb9ec1a360e} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46218) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.197448 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.244651 [ 3766 ] {847ed3f1-5d98-445f-8ee9-53b412fc8608} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndex: In scope SELECT multiSearchFirstIndex(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45708) (comment: 02294_stringsearch_with_nonconst_needle.sql) (query 25, line 53) (in query: select multiSearchFirstIndex(materialize('Hello World'), materialize([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f045477 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.355217 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndex: In scope SELECT multiSearchFirstIndex(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f045477 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.357922 [ 34277 ] {79a2bd08-5a9a-4ca9-bcc0-b9dc50c404b1} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1400, line 467) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.363145 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.543515 [ 32979 ] {5e6b0be8-4e66-4b23-95cf-6d3a81f3a357} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, 1048575_UInt32 :: 1) -> plus(__table1.f, 1048575_UInt32) Decimal(38, 38) : 5'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46154) (comment: 01732_bigint_ubsan.sql) (query 5, line 10) (in query: SELECT f + 1048575, f - 21, f - 84, f * 21, f * -21, f / 21, f / 84 FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001fb9dcf6 6. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fc9abd8 7. 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 @ 0x000000001fe49df1 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe49463 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001fe4920a 10. 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&&) @ 0x000000001fe4547c 11. 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 @ 0x000000001fd142d2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd13cff 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:36:26.557526 [ 32979 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, 1048575_UInt32 :: 1) -> plus(__table1.f, 1048575_UInt32) Decimal(38, 38) : 5'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001fb9dcf6 6. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fc9abd8 7. 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 @ 0x000000001fe49df1 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe49463 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001fe4920a 10. 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&&) @ 0x000000001fe4547c 11. 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 @ 0x000000001fd142d2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd13cff 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.569554 [ 3863 ] {ae70bc95-cd2c-49eb-9d12-284c09e4750d} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46260) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.586375 [ 3863 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7d15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.841509 [ 32979 ] {c9401875-b105-4ed4-938e-b11fee0b3692} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, -2_Int8 :: 1) -> plus(__table1.f, -2_Int8) Decimal(38, 38) : 6'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46154) (comment: 01732_bigint_ubsan.sql) (query 6, line 11) (in query: SELECT f + -2, f - 21, f - 84, f * 21, f * -21, f / 9223372036854775807, f / 84 FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001fb9dcf6 6. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fc9abd8 7. _ZNK2DB24FunctionBinaryArithmeticINS_8PlusImplENS_8NamePlusELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDB8_EESB_SB_SE_NS_13ColumnDecimalISA_EENS_12ColumnVectorISD_EEEEN3COWINS_7IColumnEE13immutable_ptrISK_EERKT2_RKT3_PKNS_11ColumnConstESW_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000001fe4f11b 8. 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 @ 0x000000001fe4e763 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001fe4e50a 10. 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&&) @ 0x000000001fe4567c 11. 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 @ 0x000000001fd142d2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd13cff 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:36:26.847129 [ 32979 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, -2_Int8 :: 1) -> plus(__table1.f, -2_Int8) Decimal(38, 38) : 6'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001fb9dcf6 6. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fc9abd8 7. _ZNK2DB24FunctionBinaryArithmeticINS_8PlusImplENS_8NamePlusELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDB8_EESB_SB_SE_NS_13ColumnDecimalISA_EENS_12ColumnVectorISD_EEEEN3COWINS_7IColumnEE13immutable_ptrISK_EERKT2_RKT3_PKNS_11ColumnConstESW_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000001fe4f11b 8. 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 @ 0x000000001fe4e763 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001fe4e50a 10. 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&&) @ 0x000000001fe4567c 11. 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 @ 0x000000001fd142d2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd13cff 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0ec23 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0b540 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd09448 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.898381 [ 34277 ] {3e81c20a-fd2d-4353-ad3c-2cb844926ee4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1403, line 468) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:26.913969 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.219282 [ 3766 ] {7933a99e-f3a3-4ab2-b689-de1db434bfc3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPosition: In scope SELECT multiSearchFirstPosition(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45708) (comment: 02294_stringsearch_with_nonconst_needle.sql) (query 34, line 63) (in query: select multiSearchFirstPosition(materialize('Hello World'), materialize([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f053c17 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.225576 [ 3766 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPosition: In scope SELECT multiSearchFirstPosition(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f053c17 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.289397 [ 34277 ] {04b79223-b61f-4838-8e3c-3e21aeba73f9} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1409, line 470) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.320484 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.683868 [ 6249 ] {d53980fe-563a-4163-abc8-ea0bfe22f0e7} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 12, line 18) (in query: SELECT tupleElement(number, 1) FROM numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0550b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.695067 [ 6249 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0550b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.791704 [ 6249 ] {6a1155e6-0926-4582-8153-382a17f989fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 13, line 19) (in query: SELECT tupleElement(t1) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.800694 [ 6249 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.936520 [ 6249 ] {db5c3cfb-fa87-46db-b2e4-199e094d95e1} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 14, line 20) (in query: SELECT tupleElement(t1, 'b') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.941713 [ 6249 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:28.992331 [ 57044 ] {749bd59c-0e51-4ce3-ba2f-a81c9b64746b} 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.3.20372.altinityantalya (altinity build)) (from [::1]:46364) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ae153d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc19088 11. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 12. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 13. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 15. ./build_docker/./src/TableFunctions/TableFunctionFactory.cpp:53: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b3cc4d4 16. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:157: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c3f3 17. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.009068 [ 57044 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020ae153d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc19088 11. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e278572 12. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a707 13. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e27a925 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002852eb1e 15. ./build_docker/./src/TableFunctions/TableFunctionFactory.cpp:53: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b3cc4d4 16. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:157: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000002e33c3f3 17. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000002e33abd7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.170549 [ 6249 ] {712f8178-4a3e-4a47-b17f-a2a1ca691953} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 15, line 21) (in query: SELECT tupleElement(t1, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.184084 [ 6249 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.264889 [ 6249 ] {b2a6ce4e-ebad-4d45-941f-8cda7430c7f1} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 16, line 22) (in query: SELECT tupleElement(t1, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.270180 [ 6249 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.350466 [ 6249 ] {333fb24c-21d1-41bb-b100-47f10ca77f29} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 17, line 23) (in query: SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:29.360430 [ 6249 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.297643 [ 6249 ] {8056b506-4ad2-43d0-a4bf-4409140eea9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 22, line 31) (in query: SELECT tupleElement(t2) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.318813 [ 6249 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000182c6dcf 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0539c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.445906 [ 6249 ] {03c96748-448f-4b6f-8e64-016e82391ea8} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 23, line 32) (in query: SELECT tupleElement(t2, 'a') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.459605 [ 6249 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05a40 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.524859 [ 6249 ] {11a8ca5b-1694-4583-bd1c-da381664832c} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 24, line 33) (in query: SELECT tupleElement(t2, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.529299 [ 6249 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.662729 [ 6249 ] {20284921-d930-4837-aab2-78762ad6c6bb} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 25, line 34) (in query: SELECT tupleElement(t2, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.666797 [ 6249 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c82c0f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05b08 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.770408 [ 6249 ] {cbf2da3a-a24e-4819-a10a-122379b7a27b} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46256) (comment: 02116_tuple_element_analyzer.sql) (query 26, line 35) (in query: SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:30.777436 [ 6249 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x0000000020d05c25 6. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d05099 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:36:32.199578 [ 5476 ] {0b5eff9f-521a-41b5-86be-28ac258c2fa6} executeQuery: Code: 427. DB::Exception: Invalid regexp '[]': missing ]: []. (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58278) (comment: 03227_json_invalid_regexp.sql) (query 2, line 2) (in query: create table test (json JSON(SKIP REGEXP '[]')) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c45e420 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b8c1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b693 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b4aa 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c4664ac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:36:32.233794 [ 5476 ] {} TCPHandler: Code: 427. DB::Exception: Invalid regexp '[]': missing ]: []. (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c45e420 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b8c1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b693 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b4aa 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c4664ac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:36:32.329750 [ 5476 ] {226fead1-0466-4c25-8518-54a4954f3097} executeQuery: Code: 427. DB::Exception: Invalid regexp '+': no argument for repetition operator: +. (CANNOT_COMPILE_REGEXP) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58278) (comment: 03227_json_invalid_regexp.sql) (query 3, line 3) (in query: create table test (json JSON(SKIP REGEXP '+')) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c45e420 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b8c1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b693 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b4aa 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c4664ac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:36:32.340215 [ 5476 ] {} TCPHandler: Code: 427. DB::Exception: Invalid regexp '+': no argument for repetition operator: +. (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccedef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c45e420 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b8c1 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b693 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c46b4aa 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c4664ac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:36:32.514583 [ 4938 ] {157216ac-4983-4a00-82e3-f2fe53e02be8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58152) (comment: 01941_dict_get_has_complex_single_key.sql) (query 16, line 25) (in query: DROP DICTIONARY test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:36:32.520472 [ 4938 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:36:33.931257 [ 6915 ] {} test_7.t0 (0edd5c95-ca07-45b9-881b-d92976f93c87): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:36:34.046372 [ 34340 ] {589ce315-2841-4bab-84ca-c0bf3ee6af91} executeQuery: Code: 397. DB::Exception: MATERIALIZED VIEW support query with multiple simple UNION [ALL] only. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58436) (comment: 03247_materialized_view_select_intersect.sql) (query 1, line 1) (in query: CREATE MATERIALIZED VIEW v0 AS (SELECT 1) INTERSECT (SELECT 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x000000003037ffc6 6. ./build_docker/./src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003037f506 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:143: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000304d88b4 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304efb26 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304ef90a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000304ec72f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:36:34.078152 [ 34340 ] {} TCPHandler: Code: 397. DB::Exception: MATERIALIZED VIEW support query with multiple simple UNION [ALL] only. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x000000003037ffc6 6. ./build_docker/./src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003037f506 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:143: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000304d88b4 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, std::allocator, 0>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304efb26 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000304ef90a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000304ec72f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:36:34.480042 [ 6915 ] {} DatabaseCatalog: Cannot drop table test_7.t0 (0edd5c95-ca07-45b9-881b-d92976f93c87). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:39.096074 [ 57039 ] {ad53c9bf-5176-42e0-a3ab-3d1db76338ef} executeQuery: Code: 497. DB::Exception: test_3_restricted_user_1983312038: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39654) (comment: 02885_async_insert_access_check_for_defaults.sh) (query 1, line 1) (in query: INSERT INTO table_with_default (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002d4c6004 9. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002d4878a5 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f47d29 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43c84 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7e235 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 27. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 28. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:36:39.114801 [ 57039 ] {} TCPHandler: Code: 497. DB::Exception: test_3_restricted_user_1983312038: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002d4c6004 9. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002d4878a5 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f47d29 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43c84 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7e235 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000318239a3 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x0000000031844d56 27. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316c0e72 28. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316ad589 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:36:39.516809 [ 6951 ] {de948118-2940-47e8-859a-fbe66ca9873a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElementOrNull. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58092) (comment: 03240_array_element_or_null.sql) (query 49, line 65) (in query: select arrayElementOrNull(m, 0), materialize(map('key', 42)) as m;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022a9a5b1 6. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022a95b49 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 17. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 18. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:39.535502 [ 6951 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElementOrNull. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022a9a5b1 6. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022a95b49 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb237ae 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb2231e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dc57bf 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320f57db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3c8db6 17. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd8453e 18. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd80905 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd70839 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad936 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:36:39.868921 [ 6922 ] {bdd40fcd-b082-47e6-94d5-db8fef1a1ccf} executeQuery: Code: 497. DB::Exception: test_3_restricted_user_1983312038: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO test_3.table_with_default (key) FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002d4c6004 9. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002d4878a5 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f47d29 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43c84 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7e235 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 2025.07.13 02:36:39.873945 [ 6922 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_3.table_with_default (key) FORMAT Values': Code: 497. DB::Exception: test_3_restricted_user_1983312038: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002d4c6004 9. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002d4878a5 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f47d29 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43c84 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7e235 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:39.881013 [ 32979 ] {0e84d637-b76e-4261-8f60-da1d4d7bd764} executeQuery: Code: 497. DB::Exception: test_3_restricted_user_1983312038: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39660) (comment: 02885_async_insert_access_check_for_defaults.sh) (query 1, line 1) (in query: INSERT INTO table_with_default (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002d4c6004 9. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002d4878a5 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f47d29 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43c84 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7e235 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 2025.07.13 02:36:39.903553 [ 32979 ] {} TCPHandler: Code: 497. DB::Exception: test_3_restricted_user_1983312038: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_3.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e534 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd5d190 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002bd5c4c5 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 8. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002d4c6004 9. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002d4878a5 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f47d29 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43c84 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7e235 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000031dc609e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000318211a0 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d40a033 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40e86b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 2025.07.13 02:36:40.809436 [ 33006 ] {defd188e-76bc-4763-b37e-c43c352a0ce0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58378) (comment: 03132_sqlancer_union_all.sql) (query 9, line 11) (in query: CREATE TABLE t2 (`c0` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 61770, 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 = 83280781, compact_parts_max_bytes_to_buffer = 505739673, compact_parts_max_granules_to_buffer = 183, compact_parts_merge_max_bytes_to_prefetch_part = 17134616, merge_max_block_size = 3728, old_parts_lifetime = 314., prefer_fetch_merged_part_size_threshold = 2814576355, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4543194028, index_granularity_bytes = 3876013, 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 = 62446, primary_key_compress_block_size = 35047, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:36:40.832527 [ 33006 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c9bc5a 9. ./build_docker/./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>) @ 0x00000000311d0325 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf8bb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311cf64f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c8ab4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:36:41.429000 [ 5480 ] {5050caa4-a002-44a0-8001-dca2bc85337e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39724) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:41.446252 [ 5480 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:42.235855 [ 6889 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c573dc3e-5017-49e3-869e-77c48aca1408', leaving the previous version, next update is scheduled at 2025-07-13 02:38:36: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.datetime_table' in scope SELECT CountryID, StartDate, EndDate, Tax FROM test_11.datetime_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc595d1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x00000000288f7438 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x00000000288f70df 19. ./src/Dictionaries/RangeHashedDictionary.h:544: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::loadData() @ 0x00000000293c075e 20. ./src/Dictionaries/RangeHashedDictionary.h:341: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::RangeHashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime, DB::RangeHashedDictionaryConfiguration, std::shared_ptr) @ 0x00000000293bfb70 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107], DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, std::allocator>, 0>(std::allocator>, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eec99 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::ExternalLoadableLifetime const&, DB::RangeHashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x00000000293eea4a 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::RangeHashedDictionary<(DB::DictionaryKeyType)0>::clone() const @ 0x00000000293c1470 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dc0021c 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbfe09f 26. ./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()() @ 0x000000002dc04df1 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:42.287683 [ 34277 ] {2cf390b0-3b93-4d88-9258-e585fed98859} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1457, line 486) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:42.293551 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:42.960209 [ 57039 ] {4c74a41d-940a-4276-b8a6-004a0251a509} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39738) (comment: 02576_rewrite_array_exists_to_has.sql) (query 8, line 11) (in query: set enable_analyzer = false;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:42.977706 [ 57039 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:36:45.521970 [ 57039 ] {} DynamicQueryHandler: Code: 48. DB::Exception: Unsupported compression method. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/IO/CompressionMethod.cpp:197: std::unique_ptr> DB::createWriteCompressedWrapper(DB::WriteBuffer*&, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x0000000023e6704b 6. ./build_docker/./src/IO/CompressionMethod.cpp:231: DB::wrapWriteBufferWithCompressionMethod(DB::WriteBuffer*, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x0000000023e668ed 7. ./build_docker/./src/Server/HTTPHandler.cpp:314: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bd0b3 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:45.528330 [ 5380 ] {9742ba5a-14c7-4d57-b573-ad10444b274b} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39784) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:45.562896 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:46.547363 [ 5476 ] {64ba056d-b42e-4658-9c45-4c42f248d941} executeQuery: Code: 432. DB::Exception: Unknown codec family: gbdgkjsdh. (UNKNOWN_CODEC) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58576) (comment: 00804_test_alter_compression_codecs.sql) (query 31, line 53) (in query: ALTER TABLE alter_bad_codec ADD COLUMN alter_column DateTime DEFAULT '2019-01-01 00:00:00' CODEC(gbdgkjsdh);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Compression/CompressionFactory.cpp:124: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x0000000032db9d84 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] 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&) @ 0x0000000032e02123 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032dffa7c 10. ./build_docker/./src/Storages/AlterCommands.cpp:1462: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d4078 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:46.554060 [ 5476 ] {} TCPHandler: Code: 432. DB::Exception: Unknown codec family: gbdgkjsdh. (UNKNOWN_CODEC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Compression/CompressionFactory.cpp:124: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x0000000032db9d84 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] 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&) @ 0x0000000032e02123 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032dffa7c 10. ./build_docker/./src/Storages/AlterCommands.cpp:1462: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d4078 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:46.856651 [ 5476 ] {a587ee03-13ce-45ba-906b-edc6ddb7a288} executeQuery: Code: 433. DB::Exception: ZSTD codec can't have level more than 22, given 100. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58576) (comment: 00804_test_alter_compression_codecs.sql) (query 32, line 55) (in query: ALTER TABLE alter_bad_codec ADD COLUMN alter_column DateTime DEFAULT '2019-01-01 00:00:00' CODEC(ZSTD(100));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&&, int&) @ 0x0000000032dc4a6f 5. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:104: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000032dc3de1 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] 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&) @ 0x0000000032e02123 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032dffa7c 10. ./build_docker/./src/Storages/AlterCommands.cpp:1462: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d4078 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:46.862006 [ 5476 ] {} TCPHandler: Code: 433. DB::Exception: ZSTD codec can't have level more than 22, given 100. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&&, int&) @ 0x0000000032dc4a6f 5. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:104: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000032dc3de1 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] 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&) @ 0x0000000032e02123 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032dffa7c 10. ./build_docker/./src/Storages/AlterCommands.cpp:1462: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302d4078 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c875 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:36:48.516511 [ 34277 ] {8cc3ff46-3f79-435e-b452-63466fa0dbc4} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1487, line 496) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:48.544217 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:49.208063 [ 57044 ] {6f8a1426-bdb3-47e9-840e-3811141bad58} executeQuery: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39896) (comment: 00700_decimal_bounds.sql) (query 2, line 3) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(10, -2)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x000000002b7358be 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:36:49.236851 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x000000002b7358be 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:36:49.343587 [ 57044 ] {e250c195-8136-4609-adda-d231d6e63b41} executeQuery: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39896) (comment: 00700_decimal_bounds.sql) (query 3, line 4) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(10, 15)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x000000002b7358be 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:36:49.347973 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x000000002b7358be 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:36:49.529906 [ 57044 ] {3c7c7cfc-3aac-42b9-8f57-ffc1a0cc3a42} executeQuery: Code: 69. DB::Exception: Wrong precision: it must be between 1 and 76, got 0. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39896) (comment: 00700_decimal_bounds.sql) (query 4, line 5) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(0, 0)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, unsigned long&&, unsigned long&) @ 0x000000002b74b00f 5. ./src/DataTypes/DataTypeDecimalBase.h:173: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x000000002b735862 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:36:49.533606 [ 57044 ] {} TCPHandler: Code: 69. DB::Exception: Wrong precision: it must be between 1 and 76, got 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, unsigned long&&, unsigned long&) @ 0x000000002b74b00f 5. ./src/DataTypes/DataTypeDecimalBase.h:173: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x000000002b735862 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c42c3a0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc65f15 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc66999 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc69a7a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7cc47 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:36:51.209940 [ 5380 ] {2e515fe6-3e22-4649-9bc0-3f5aab1265b3} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39784) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:51.216769 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002b812a6f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003038ac39 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:51.240727 [ 5826 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:36:51.672783 [ 5380 ] {22c41842-3c2b-48a7-900c-0e9aabc77c8f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39784) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:36:51.698483 [ 5380 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb40f1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:36:51.774095 [ 34277 ] {e2fcd5ff-7d7e-45ab-91ac-1d2ea4e967af} executeQuery: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 00763_lock_buffer_long.sh) (query 1499, line 500) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 17072, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1865595579147339, 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 = 201508793, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8925807, merge_max_block_size = 23441, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26915236, 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 = 85257, primary_key_compress_block_size = 35439, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:51.789507 [ 34277 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:56.746860 [ 46296 ] {abd05664-db05-4da7-9223-a0d06823a4f1} executeQuery: Code: 57. DB::Exception: Table test_3.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44490) (comment: 03267_join_swap_bug.sql) (query 2, line 2) (in query: CREATE TABLE t0 (`c0` Int) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 32599, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8531894087791443, 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 = 68869495, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 11281308, merge_max_block_size = 4450, 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 = 66, min_merge_bytes_to_use_direct_io = 9095754427, index_granularity_bytes = 4915666, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 22, 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 = 85357, primary_key_compress_block_size = 20318, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:56.850669 [ 46296 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:57.469346 [ 6951 ] {b2f409e1-e578-4660-a2e8-a9d5fd64032e} executeQuery: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing WITH x AS (SELECT number FROM numbers(10)), cross_sales AS (SELECT 1 AS xx FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9 WHERE x.number = d9.number) SELECT xx FROM cross_sales WHERE xx = 2000. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44520) (comment: 02337_join_analyze_stuck.sql) (query 1, line 3) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/21557 EXPLAIN SYNTAX WITH x AS ( SELECT number FROM numbers(10) ), cross_sales AS ( SELECT 1 AS xx FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9 WHERE x.number = d9.number ) SELECT xx FROM cross_sales WHERE xx = 2000 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1077: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x000000002d65ba3c 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x000000002d658f8a 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002d66c6e6 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x000000002dd2dca1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: 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 @ 0x000000002dd1b73f 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: 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) @ 0x000000002dd11fe5 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd0a233 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000002de242a6 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de21af9 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de202c3 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002de2511b 16. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x000000002e2d5587 17. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x000000002de63128 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:588: 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) @ 0x000000002dd0bbf2 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd0a233 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000002de242a6 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de21af9 22. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de202c3 23. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002de2511b 24. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x000000002e2d5587 25. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x000000002de63128 26. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:588: 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) @ 0x000000002dd0bbf2 27. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd0a233 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000002de242a6 29. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de21af9 30. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de202c3 31. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002de2511b 2025.07.13 02:36:57.528786 [ 6951 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing WITH x AS (SELECT number FROM numbers(10)), cross_sales AS (SELECT 1 AS xx FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9 WHERE x.number = d9.number) SELECT xx FROM cross_sales WHERE xx = 2000. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1077: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x000000002d65ba3c 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x000000002d658f8a 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002d66c6e6 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x000000002dd2dca1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: 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 @ 0x000000002dd1b73f 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: 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) @ 0x000000002dd11fe5 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd0a233 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000002de242a6 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de21af9 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de202c3 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002de2511b 16. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x000000002e2d5587 17. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x000000002de63128 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:588: 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) @ 0x000000002dd0bbf2 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd0a233 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000002de242a6 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de21af9 22. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de202c3 23. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002de2511b 24. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x000000002e2d5587 25. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x000000002de63128 26. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:588: 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) @ 0x000000002dd0bbf2 27. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd0a233 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000002de242a6 29. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de21af9 30. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002de202c3 31. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002de2511b 2025.07.13 02:36:58.080084 [ 6951 ] {e7e5a2ba-b05d-4455-82ef-1df28d92fa10} executeQuery: Code: 36. DB::Exception: Table function 's3Cluster' cannot be used to create a table. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44578) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ITableFunctionCluster>::validateUseToCreateTable() const @ 0x00000000285a5727 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1928: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88d7d 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:58.100152 [ 6951 ] {} TCPHandler: Code: 36. DB::Exception: Table function 's3Cluster' cannot be used to create a table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::ITableFunctionCluster>::validateUseToCreateTable() const @ 0x00000000285a5727 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1928: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88d7d 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:36:58.976667 [ 6951 ] {e6880307-5a41-4b3b-83d4-2df7a3b0f266} 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.3.20372.altinityantalya (altinity build)) (from [::1]:44596) (comment: 00549_join_use_nulls.sql) (query 4, line 6) (in query: INSERT INTO null_00549 SELECT k, a, b FROM ( SELECT number AS k, toString(number) AS a FROM system.numbers LIMIT 2 ) js1 ANY LEFT JOIN ( SELECT number AS k, toString(number) AS b FROM system.numbers LIMIT 1, 2 ) js2 USING (k) ORDER BY k ASC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffaa7 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:267: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd704f2 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcebe9d 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:59.005917 [ 6951 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddffaa7 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: 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&) @ 0x000000002ddba41c 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: 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&) @ 0x000000002ddb77dc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dda3790 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd78b9a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd73cf9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:267: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd704f2 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcebe9d 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:36:59.993852 [ 7056 ] {fc539d1d-dd54-48b1-ad1f-442c16d6300d} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e'). (UNKNOWN_SETTING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41448) (comment: 03234_get_setting_or_default.sql) (query 9, line 11) (in query: SELECT getSetting('custom_e');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c08be60 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c2893c7 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c2891c8 7. ./build_docker/./src/Core/Settings.cpp:6487: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c18d0d8 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc3078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc2eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:37:00.014728 [ 7056 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e'). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c08be60 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c2893c7 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c2891c8 7. ./build_docker/./src/Core/Settings.cpp:6487: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c18d0d8 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc3078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc2eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 2025.07.13 02:37:00.513831 [ 5732 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:37:00.514828 [ 5732 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf8c7 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 2025.07.13 02:37:00.531847 [ 7056 ] {5576e423-60c1-415b-b453-ab2617636755} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault('custom_e'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41448) (comment: 03234_get_setting_or_default.sql) (query 14, line 18) (in query: SELECT getSettingOrDefault('custom_e');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:37:00.534599 [ 7056 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault('custom_e'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 28. ? @ 0x00007f9c53164ac3 29. ? @ 0x00007f9c531f6850 2025.07.13 02:37:00.622982 [ 5971 ] {fdaa7b46-3305-4ac7-9fef-260a4b3fed11} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41496) (comment: 00494_shard_alias_substitution_bug.sql) (query 4, line 6) (in query: SELECT 1 AS x FROM remote('127.0.0.2', currentDatabase(), nested) ARRAY JOIN n.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e 2025.07.13 02:37:00.639196 [ 5971 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316cb8d6 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316bf537 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316ac759 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b35b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x0000000031487588 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000314971b4 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000315119b9 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3f79cd 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3f7640 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3f7337 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3f583e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:00.717381 [ 7056 ] {31ad81c7-5f75-4bb1-9cfc-67b8e8b5a2e5} executeQuery: Code: 43. DB::Exception: The argument of function getSettingOrDefault should be a constant string with the name of a setting: In scope SELECT getSettingOrDefault(115, 'name should be string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41448) (comment: 03234_get_setting_or_default.sql) (query 15, line 19) (in query: SELECT getSettingOrDefault(115, 'name should be string');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getValue(std::vector> const&) const @ 0x000000001afc4aa3 6. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc45d2 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:37:00.735452 [ 7056 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getSettingOrDefault should be a constant string with the name of a setting: In scope SELECT getSettingOrDefault(115, 'name should be string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getValue(std::vector> const&) const @ 0x000000001afc4aa3 6. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc45d2 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:37:01.196110 [ 5971 ] {dadfca69-4820-4392-b53c-58715a11dfce} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 2, line 3) (in query: SELECT max(multiply(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.204027 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.277213 [ 5971 ] {67765e6b-69c1-4d26-90f0-fe276774a81f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 3, line 4) (in query: SELECT min(multiply(2));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.306498 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.352364 [ 5971 ] {ab1a6874-3da7-4c95-bdc0-0b0ac6aac43a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 4, line 5) (in query: SELECT sum(multiply(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.356178 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.424623 [ 5971 ] {09088ad2-a1a7-45e0-8f18-704b6e1dc0c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 5, line 7) (in query: SELECT max(plus(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.429339 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.475331 [ 5971 ] {1ee8aae6-7eab-472e-b432-adcaa60187a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 6, line 8) (in query: SELECT min(plus(2));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.479364 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.544859 [ 5971 ] {2ecb144c-ebc4-4d66-a364-bfc61217b18b} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 7, line 9) (in query: SELECT sum(plus(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.570222 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.659853 [ 5971 ] {41c8b5bc-48e1-466e-a82f-37480cb0acbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 8, line 11) (in query: SELECT max(multiply());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.667725 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.816286 [ 5971 ] {30fee3d6-1b53-4453-8adf-ada2f25542d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 9, line 12) (in query: SELECT min(multiply(1, 2 ,3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.821318 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:01.976066 [ 5971 ] {970a65c0-532d-4357-b4f1-41e60522dc5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 10, line 13) (in query: SELECT sum(plus() + multiply());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:37:01.996314 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:37:02.066934 [ 5971 ] {a55c6861-3702-41dc-b17e-bc8dc35436d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41520) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 11, line 15) (in query: SELECT sum(plus(multiply(42, 3), multiply(42)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:37:02.071472 [ 5971 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293d7b4f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002accee8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfd2c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:37:04.610976 [ 32979 ] {a9e8806b-30e3-424e-92f1-2c96a8ca3d0b} executeQuery: Code: 36. DB::Exception: Existing column a is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41612) (comment: 00754_alter_modify_order_by.sql) (query 5, line 6) (in query: ALTER TABLE no_order MODIFY ORDER BY (a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c865a5 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:04.640359 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Existing column a is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c865a5 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.145940 [ 34260 ] {08cbf00c-be7d-4709-8fa8-91d7c1d03f41} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 1, line 1) (in query: SELECT bitAnd(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019051b33 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018f529b1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.151509 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019051b33 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018f529b1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.285607 [ 34260 ] {ed00558d-57e0-447c-a605-a868840ad103} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 2, line 2) (in query: SELECT bitXor(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019e591d3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019d59b31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.291844 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019e591d3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019d59b31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.358637 [ 34260 ] {29635b48-50b7-48a4-a960-08d5716e229b} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 3, line 3) (in query: SELECT bitOr(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019681873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000195821d1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.364176 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019681873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000195821d1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.372601 [ 57042 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:05.399875 [ 34260 ] {fe7bfd25-d169-440d-aa7d-6ebe1e25f31b} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 4, line 4) (in query: SELECT bitTest(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.406041 [ 34340 ] {05acd1e5-1776-4af7-9f38-43f1254afc0c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41666) (comment: 01825_type_json_3.gen.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.407206 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.425617 [ 34340 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.500632 [ 32979 ] {ff9ac535-1c91-468b-abae-b9d3fe33e229} executeQuery: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41612) (comment: 00754_alter_modify_order_by.sql) (query 10, line 13) (in query: ALTER TABLE old_style ADD COLUMN y UInt32, MODIFY ORDER BY (x, y);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3698: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd5bdd 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.537236 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3698: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd5bdd 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.537848 [ 34260 ] {c76e4f33-e485-4da1-be5c-27ae7103f2ed} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 5, line 5) (in query: SELECT bitTest(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.544153 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019d04873 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019c14771 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.650032 [ 34260 ] {0520cc39-064e-44fc-8cc2-ccfe717c1b19} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 6, line 6) (in query: SELECT bitRotateLeft(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000197bd293 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000196bbc31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.666793 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000197bd293 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000196bbc31 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.744486 [ 34260 ] {1b2d30e9-1d12-4cbd-a878-bff6643edfc6} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 7, line 7) (in query: SELECT bitRotateRight(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000198f8df3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000197f7791 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.752661 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000198f8df3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000197f7791 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.793026 [ 34260 ] {ea7110b4-7dd6-4ac2-bba4-b60610755de4} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 8, line 8) (in query: SELECT bitShiftLeft(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019a599f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019932df1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.796951 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019a599f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019932df1 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.855454 [ 34260 ] {313dc837-67ec-4876-a246-3dfeb5f356e5} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41646) (comment: 01677_bit_float.sql) (query 9, line 9) (in query: SELECT bitShiftRight(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019bb96f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019a95491 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.866176 [ 32979 ] {77a8cc61-8ab7-410c-ba94-de59144c43a2} executeQuery: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41612) (comment: 00754_alter_modify_order_by.sql) (query 14, line 19) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing MODIFY ORDER BY (x, y, -val);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c865a5 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.867072 [ 34260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0bf4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019bb96f3 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019a95491 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d9734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 31. ? @ 0x00007f9c53164ac3 2025.07.13 02:37:05.884051 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c865a5 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.973272 [ 32979 ] {bbc18d13-fdf0-492f-a32d-2ea1cf8590ca} executeQuery: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41612) (comment: 00754_alter_modify_order_by.sql) (query 15, line 22) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing ADD COLUMN z UInt32 DEFAULT x + 1, MODIFY ORDER BY (x, y, -z);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:787: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c8690c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:05.978027 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:787: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c8690c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:06.135437 [ 32979 ] {8ea8ee5f-ea67-4978-a66b-5bdd359742bc} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent', available columns: 'val' 'y' 'x'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41612) (comment: 00754_alter_modify_order_by.sql) (query 16, line 25) (in query: /* Can't add nonexistent column to ORDER BY. */ ALTER TABLE summing MODIFY ORDER BY (x, y, nonexistent);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000002e1ae42c 5. ./build_docker/./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 @ 0x000000002e1bcf13 6. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033a7ea 7. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003033a0cf 8. ./build_docker/./src/Storages/AlterCommands.cpp:666: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c789a 9. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:37:06.142938 [ 32979 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent', available columns: 'val' 'y' 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000002e1ae42c 5. ./build_docker/./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 @ 0x000000002e1bcf13 6. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003033a7ea 7. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003033a0cf 8. ./build_docker/./src/Storages/AlterCommands.cpp:666: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c789a 9. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302d0d59 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd1e89 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 21. ? @ 0x00007f9c53164ac3 22. ? @ 0x00007f9c531f6850 2025.07.13 02:37:06.331851 [ 32979 ] {0c989f6f-574a-4025-8b36-3abfbfe7792a} executeQuery: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41612) (comment: 00754_alter_modify_order_by.sql) (query 17, line 28) (in query: /* Can't modyfy ORDER BY so that it is no longer a prefix of the PRIMARY KEY. */ ALTER TABLE summing MODIFY ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:720: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c86b7f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:06.376821 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:720: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c86b7f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cd42fd 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4c90a 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:37:07.771156 [ 6024 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:39594). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:422: DB::TCPHandler::runImpl() @ 0x00000000316b3019 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:07.771723 [ 6024 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39594, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:07.773943 [ 6024 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39594, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5c455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316be37e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316aab72 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:08.108478 [ 34273 ] {a6e9a7d5-a7b0-4b7c-aa98-63777f2e9558} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41280) (comment: 00754_alter_modify_order_by.sql) (in query: DROP DATABASE IF EXISTS test_s6u3pfti SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:37:08.112631 [ 34273 ] {a6e9a7d5-a7b0-4b7c-aa98-63777f2e9558} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:08.714544 [ 5480 ] {936eea70-409d-419c-8093-4ab2c3fff33c} executeQuery: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41750) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000278c27aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:37:08.719742 [ 5480 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000278c27aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3a86b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3a6aa7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3c9cd 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 2025.07.13 02:37:10.083239 [ 6024 ] {bd238fca-951c-4b6e-815e-3900d4b304d4} executeQuery: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37648) (comment: 02353_translate.sql) (query 9, line 12) (in query: SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x0000000020ceb28b 6. DB::TranslateImpl::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, String const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000020cea9c2 7. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ce76d8 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:37:10.109660 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x0000000020ceb28b 6. DB::TranslateImpl::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, String const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000020cea9c2 7. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ce76d8 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:37:11.284269 [ 6024 ] {b495b26d-1edb-4825-8a15-bb6b4a3051e1} executeQuery: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('aAbBcC', '中文内ç ', '12'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37648) (comment: 02353_translate.sql) (query 16, line 21) (in query: SELECT translate('aAbBcC', '中文内ç ', '12');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x0000000020ceb28b 6. DB::TranslateImpl::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, String const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000020cea9c2 7. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ce76d8 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:37:11.311355 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('aAbBcC', '中文内ç ', '12'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x0000000020ceb28b 6. DB::TranslateImpl::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, String const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000020cea9c2 7. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ce76d8 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:37:11.484167 [ 6024 ] {01751bc2-7b91-4df7-9b64-b7d71c260c7d} executeQuery: Code: 36. DB::Exception: Second argument of function translate must not be shorter than the third argument. Size of the second argument: 2, size of the third argument: 3: In scope SELECT translate('aAbBcC', 'ab', 'abc'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37648) (comment: 02353_translate.sql) (query 17, line 23) (in query: SELECT translate('aAbBcC', 'ab', 'abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&&) @ 0x0000000017f47fcf 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ce7e32 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:37:11.486743 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: Second argument of function translate must not be shorter than the third argument. Size of the second argument: 2, size of the third argument: 3: In scope SELECT translate('aAbBcC', 'ab', 'abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long&&) @ 0x0000000017f47fcf 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020ce7e32 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:37:11.968479 [ 3815 ] {3dccc9fe-52fc-473c-8949-92d8c413533d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38074) (comment: 01825_type_json_in_array.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:37:11.991061 [ 3815 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:37:12.235749 [ 4142 ] {8042a6a0-91b4-4485-96c1-d9f06dc906f1} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 46.98 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37810) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 2025.07.13 02:37:12.304879 [ 4142 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 46.98 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:12.504950 [ 6024 ] {f2c52627-12ed-431a-8cfb-f50b5c90c0dd} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:38206). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38206) (comment: 02532_send_logs_level_test.sh) (query 1, line 1) (in query: select * from data SETTINGS merge_tree_read_split_ranges_into_intersecting_and_non_intersecting_injection_probability = 0.0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:727: DB::TCPHandler::runImpl() @ 0x00000000316ad699 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:12.510878 [ 6024 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:38206). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:727: DB::TCPHandler::runImpl() @ 0x00000000316ad699 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:12.824215 [ 36852 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003117f00d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003117ef02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x0000000032823380 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x00000000328210b2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x000000003281ffaf 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003282d1fe 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:12.832629 [ 3084 ] {} test_3.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.834909 [ 3127 ] {} test_1.t1_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.837126 [ 3037 ] {} test_13.test_table_for_in (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.837770 [ 2920 ] {} test_3.deduplication (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.840759 [ 3085 ] {} test_3ka5zlz3.test_without_merge (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.841334 [ 3058 ] {} test_11.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.843417 [ 2954 ] {} test_1.t1_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.845709 [ 3091 ] {} test_13.dep2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.848149 [ 3122 ] {} test_1.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.850286 [ 2917 ] {} test_3.zero_rows_per_granule2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.853740 [ 3100 ] {} test_1.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.858040 [ 3112 ] {} test_15.data_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.871352 [ 3144 ] {} test_15.data_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.873456 [ 3086 ] {} test_11.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:37:12.876557 [ 3161 ] {} test_11.t_json_3 (471d5cd2-e7cc-4e9f-a4a9-e55ecbd920f1): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:12.876619 [ 3264 ] {} test_11.quorum1 (92edb6c1-f64d-4495-a21c-05900061acb1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_11/test_00732/quorum_old_data/replicas/1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3c4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003063ff0f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:12.876772 [ 3204 ] {} test_11.quorum1 (92edb6c1-f64d-4495-a21c-05900061acb1): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:12.897094 [ 3117 ] {} test_11.table_rename_with_ttl (eeb1a6b1-7d85-41e4-8643-9f73eae7461c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282a8ba 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275e51a 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275df95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ee14 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003275ecb5 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003111459d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003064073e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c08208c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c086397 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c0873e6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:13.584503 [ 3467 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-7_18_18_0_27} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=4). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:13.728834 [ 3467 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-7_18_18_0_27} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 27. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 28. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1387: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x000000002deba308 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1457: DB::MutationsInterpreter::execute() @ 0x000000002debe5c6 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2331: DB::MutateTask::prepare() @ 0x0000000031023860 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:13.739049 [ 3467 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-7_18_18_0_27}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 27. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 28. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1387: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x000000002deba308 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1457: DB::MutationsInterpreter::execute() @ 0x000000002debe5c6 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2331: DB::MutateTask::prepare() @ 0x0000000031023860 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:15.733266 [ 3815 ] {0af57ddd-0c47-44cb-9705-57036243cda0} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 47.73 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38794) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 16. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:37:15.841384 [ 3815 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 47.73 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 16. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:16.575875 [ 3452 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-2_48_48_0_107} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=3). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:17.076496 [ 5382 ] {c9d5ef1c-8a7c-4f24-a4c8-14f05d0a901d} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 41.73 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38734) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 2025.07.13 02:37:17.111168 [ 5382 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 41.73 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:17.155819 [ 3452 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-2_48_48_0_107} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 26. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 27. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 28. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1387: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x000000002deba308 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1457: DB::MutationsInterpreter::execute() @ 0x000000002debe5c6 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2331: DB::MutateTask::prepare() @ 0x0000000031023860 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:17.159214 [ 3452 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-2_48_48_0_107}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 26. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 27. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 28. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1387: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x000000002deba308 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1457: DB::MutationsInterpreter::execute() @ 0x000000002debe5c6 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2331: DB::MutateTask::prepare() @ 0x0000000031023860 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:19.046091 [ 57042 ] {611b1b57-5f06-44a1-817b-578210d30a4f} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 46.10 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39480) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 2025.07.13 02:37:19.059453 [ 57042 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 46.10 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:20.505584 [ 3463 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_45_45_0_216} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:20.518389 [ 3467 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_102_102_0_225} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/1c3/1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9/-1_102_102_0_205/a.bin (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading column a): (while reading from part /var/lib/clickhouse/store/1c3/1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9/-1_102_102_0_205/ in table test_11.alter_table (1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9) located on disk default of type local, from mark 0 with max_rows_to_read = 305): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:20.588658 [ 3463 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_45_45_0_216} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:20.592738 [ 3463 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_45_45_0_216}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:20.620648 [ 3467 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_102_102_0_225} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/1c3/1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9/-1_102_102_0_205/a.bin (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading column a): (while reading from part /var/lib/clickhouse/store/1c3/1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9/-1_102_102_0_205/ in table test_11.alter_table (1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9) located on disk default of type local, from mark 0 with max_rows_to_read = 305): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c600dbc 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:20.627700 [ 3467 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_102_102_0_225}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=60, jobs=0): While reading or decompressing /var/lib/clickhouse/store/1c3/1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9/-1_102_102_0_205/a.bin (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading column a): (while reading from part /var/lib/clickhouse/store/1c3/1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9/-1_102_102_0_205/ in table test_11.alter_table (1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9) located on disk default of type local, from mark 0 with max_rows_to_read = 305): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b3f2359 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b3f21b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3f07dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3dc184 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3dcd80 12. DB::ReadBuffer::next() @ 0x0000000017e75832 13. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032da7b75 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032daedb2 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c600dbc 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c537ca7 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f62d9c 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f61ca3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f42c8f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f43081 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f4eac5 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f7f3b5 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f79eb1 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321f73f1 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f8869f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:21.888362 [ 3453 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_45_45_0_254} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:22.019069 [ 3453 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_45_45_0_254} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:22.107068 [ 3453 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_45_45_0_254}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:22.914125 [ 32979 ] {3e252ada-3c39-482b-94ce-f6784be9f424} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 2, line 3) (in query: SELECT formatDateTime();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9929c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:22.940878 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccbf6f 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9929c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.083375 [ 32979 ] {ac37e9a5-c717-47ef-85af-54d5c9a19c89} executeQuery: Code: 43. DB::Exception: Illegal type String of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime('not a datetime', 'IGNORED'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 3, line 4) (in query: SELECT formatDateTime('not a datetime', 'IGNORED');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad99707 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.091851 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime('not a datetime', 'IGNORED'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad99707 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.150162 [ 46285 ] {9ce8a726-0478-44fb-9aa6-d49912fc4884} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 42.16 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50742) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 25. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 30. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 2025.07.13 02:37:23.209550 [ 46285 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 42.16 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 25. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 30. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.317188 [ 32979 ] {4e3cff5a-20fd-4d8e-9058-3285a1655aeb} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of second argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 4, line 5) (in query: SELECT formatDateTime(now(), now());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9942e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.337912 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of second argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9942e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.528913 [ 32979 ] {6ef4865b-fa72-44a7-8a58-557fb66fc073} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of third argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), 'good format pattern', now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 5, line 6) (in query: SELECT formatDateTime(now(), 'good format pattern', now());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad995a4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.544956 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of third argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), 'good format pattern', now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad995a4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 29. ? @ 0x00007f9c53164ac3 30. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.764713 [ 32979 ] {bc74f7a9-fd7c-4ab1-8aec-ec13b2a2dcc8} executeQuery: Code: 36. DB::Exception: '%' must not be the last character in the format string, use '%%' instead: In scope SELECT formatDateTime(now(), 'unescaped %'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 6, line 7) (in query: SELECT formatDateTime(now(), 'unescaped %');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::throwLastCharacterIsPercentException() @ 0x000000001ad99cce 6. ? @ 0x000000001ad99bbd 7. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94bb9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:37:23.784450 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: '%' must not be the last character in the format string, use '%%' instead: In scope SELECT formatDateTime(now(), 'unescaped %'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::throwLastCharacterIsPercentException() @ 0x000000001ad99cce 6. ? @ 0x000000001ad99bbd 7. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94bb9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 2025.07.13 02:37:23.914819 [ 34277 ] {5f3305f0-b6ff-465e-8089-52bf70cab1e1} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 51.84 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50662) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 22. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c691e61 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 2025.07.13 02:37:23.942450 [ 34277 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 51.84 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 22. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c691e61 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:23.964760 [ 32979 ] {30b66cfa-b8f7-41e2-8132-39cfc0d7f135} executeQuery: Code: 48. DB::Exception: format is not supported for WEEK (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U'). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 7, line 8) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada40d1 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.017156 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for WEEK (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada40d1 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.200108 [ 32979 ] {158fc21a-5329-4236-8964-91804fdf6fd0} executeQuery: Code: 48. DB::Exception: format is not supported for WEEK (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v'). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 8, line 9) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada3f5d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.212606 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for WEEK (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada3f5d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.406056 [ 32979 ] {cf988891-0872-44f6-9912-9160cbc51ca6} executeQuery: Code: 48. DB::Exception: format is not supported for YEAR for week (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x'). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 9, line 10) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada41c7 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.420685 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for YEAR for week (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada41c7 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.569370 [ 32979 ] {522e58c5-2983-4e7a-9b19-0a73c4da86db} executeQuery: Code: 48. DB::Exception: format is not supported for YEAR for week (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X'). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 10, line 11) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada4151 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:24.581929 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for YEAR for week (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada4151 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad94c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:27.246953 [ 7056 ] {56a80c2a-2b70-44ef-9a8c-09d23351cf99} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 45.00 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51336) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 2025.07.13 02:37:27.273229 [ 7056 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 45.00 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c546962 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:27.809530 [ 34273 ] {e717326b-fdfb-40b1-ad5c-e7d038cd88dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=2): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37678) (comment: 02354_read_in_order_prewhere.sql) (query 7, line 20) (in query: SELECT Num FROM order WHERE Type = 1 AND ID = 1 ORDER BY Num ASC limit 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:170: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222c37b 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 2025.07.13 02:37:27.827236 [ 46286 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40442, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:27.828300 [ 46286 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40442, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316ac6dc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:27.835764 [ 6022 ] {219d873b-8084-4fe5-a077-18fbd00e7261} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:42012). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x00000000316adce1 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:28.023402 [ 34273 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=2): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f636bc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f65fe7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f5f978 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f5f3e2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030de049f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dd8393 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f788a5 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321f1443 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:170: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222c37b 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f885a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x00000000322203f5 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003180b323 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031825a0d 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 10. ? @ 0x00007f9c53164ac3 11. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:28.786699 [ 34277 ] {6b4c8b56-cbeb-43e6-85f5-0c1df6a3addc} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51450) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: -- constant ignore will be pruned by part pruner. ignore(*) is used. SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:37:28.806686 [ 34277 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:37:28.968220 [ 34277 ] {3b6d4058-9fb3-4a1a-a530-ab62a4a5dbbf} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51450) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:37:29.006398 [ 34277 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3fe3cf 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3fd7a9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000032196510 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b9fc9 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:37:30.207900 [ 7056 ] {fe829879-0613-49ab-abaa-7e6a5e692920} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 47.74 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51642) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 16. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5ed3e1 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:37:30.226122 [ 7056 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 47.74 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 16. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5ed3e1 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:31.324042 [ 32979 ] {13e5eed4-127a-4ae4-ba9e-548cc226c0c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=869). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50794) (comment: 00718_format_datetime.sql) (query 55, line 67) (in query: SELECT formatDateTime(toDateTime('2020-01-01 01:00:00', 'Europe/Moscow'), '%z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./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&&) @ 0x000000002dbff463 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x000000002dc14bf5 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1263: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x000000002dc143e7 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::ExternalLoader::PeriodicUpdater::*&&)(), DB::ExternalLoader::PeriodicUpdater*&&)::'lambda'()::operator()() @ 0x000000002dc17734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:37:31.357144 [ 32979 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=926, jobs=869). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc78fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc00c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 7. ./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&&) @ 0x000000002dbff463 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbfc560 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x000000002dc14bf5 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1263: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x000000002dc143e7 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::ExternalLoader::PeriodicUpdater::*&&)(), DB::ExternalLoader::PeriodicUpdater*&&)::'lambda'()::operator()() @ 0x000000002dc17734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:37:32.798898 [ 73216 ] {a1dd846a-61a2-4750-9cc9-2ed03cffa907} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 47.03 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34898) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5ed3e1 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 2025.07.13 02:37:32.856011 [ 73216 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 47.03 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5ed3e1 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:34.188377 [ 5476 ] {8c1cd0ea-1a88-42c1-aceb-5132c116b40b} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 53.32 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35208) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 22. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c691e61 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 2025.07.13 02:37:34.203131 [ 5476 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 53.32 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5e9eb8 22. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c691e61 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:35.116176 [ 3863 ] {f08dd902-2950-492b-a7c6-e29c03973443} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 32.38 MiB (attempt to allocate chunk of 1.06 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35270) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000030df19ac 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030df1106 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e022e0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 2025.07.13 02:37:35.155157 [ 3863 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 32.38 MiB (attempt to allocate chunk of 1.06 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000030df19ac 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030df1106 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e022e0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:35.712280 [ 73228 ] {bd8b7949-48d9-45b8-9efa-6d8d724cc8b6} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 45.51 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35536) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 2025.07.13 02:37:35.720966 [ 73228 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 45.51 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b693f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b68671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023d00ee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c958967 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c94adf8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030b00eec 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df023f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c546f23 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:37.026800 [ 73228 ] {32400b27-b64a-4f38-9cca-4d6ad202e168} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59398) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305a(x Int8) ENGINE=Log ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd83ca5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x000000002bd82419 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd6742a 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd2a409 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4c6bc7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94d49 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:37:37.044081 [ 73228 ] {32400b27-b64a-4f38-9cca-4d6ad202e168} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd83ca5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x000000002bd82419 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd6742a 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd2a409 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4c6bc7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94d49 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:37.120166 [ 46296 ] {} DynamicQueryHandler: Code: 164. DB::Exception: Cannot modify 'readonly' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028494136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb870f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb8087 7. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 8. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:37.806387 [ 46296 ] {0bd67d94-fe21-4581-8925-60448ce6df09} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59452) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305c(x Int8) ENGINE=Log ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd83ca5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x000000002bd82419 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd6742a 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd2a409 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4c6bc7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94d49 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:37:37.810669 [ 46296 ] {0bd67d94-fe21-4581-8925-60448ce6df09} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd83ca5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x000000002bd82419 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd6742a 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd2a409 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4c6bc7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94d49 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:37.926230 [ 5480 ] {a882615b-c435-4d81-b53d-6cdf64a0b802} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 37.51 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35722) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 2025.07.13 02:37:37.938590 [ 6951 ] {181c0f02-3e4a-43b5-9fe5-767d850e86b7} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59458) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305c(x Int8) ENGINE=Log ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd83ca5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x000000002bd82419 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd6742a 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd2a409 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4c6bc7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94d49 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:37:37.944325 [ 6951 ] {181c0f02-3e4a-43b5-9fe5-767d850e86b7} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd83ca5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x000000002bd82419 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd6742a 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd2a409 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4c6bc7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94d49 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:37.985822 [ 5480 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 37.51 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x0000000023ab6837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab4846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239937a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023991de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2d2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b694b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032db12cc 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030df02f7 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e12893 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0f2fc 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c536fba 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c537225 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030e02cf4 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030e02714 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd857e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c653fb 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030ffb01e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e4edaf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e4a831 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031234e8d 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f71057 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dc546b 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dc506b 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dc41c1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031820e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 11. ? @ 0x00007f9c53164ac3 12. ? @ 0x00007f9c531f6850 2025.07.13 02:37:38.040369 [ 57042 ] {91410325-283e-42db-8079-92861539cfac} executeQuery: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36116) (comment: 03015_with_fill_invalid_expression.sql) (query 1, line 1) (in query: select number as x, number + 1 as y from numbers(5) where number % 3 == 1 order by y, x with fill from 1 to 4, y with fill from 2 to 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:287: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x00000000320ff1dc 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool const&, std::allocator, 0>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f9c43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f9a74 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320f8a3d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c37a51b 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c37a285 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320f7b92 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211eaa0 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:37:38.069117 [ 57042 ] {} TCPHandler: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:287: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x00000000320ff1dc 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool const&, std::allocator, 0>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f9c43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f9a74 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320f8a3d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c37a51b 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c37a285 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320f7b92 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211eaa0 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 24. ? @ 0x00007f9c53164ac3 25. ? @ 0x00007f9c531f6850 2025.07.13 02:37:38.137418 [ 46296 ] {71770e27-21ed-49ff-9a21-ba9eeca8eb7d} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59468) (comment: 00305_http_and_readonly.sh) (in query: DROP TABLE table_00305a ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e205 5. ./build_docker/./src/Access/ContextAccess.cpp:0: 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 @ 0x000000002bd5c9d9 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 8. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:286: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2727 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 2025.07.13 02:37:38.160439 [ 46296 ] {71770e27-21ed-49ff-9a21-ba9eeca8eb7d} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd5e205 5. ./build_docker/./src/Access/ContextAccess.cpp:0: 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 @ 0x000000002bd5c9d9 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002bd2604d 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000002d4c657a 8. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000002d4879c1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:286: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb2727 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 22. ? @ 0x00007f9c53164ac3 23. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:38.316300 [ 2824 ] {f77ef659-4f2b-44dd-bd69-80a06a5e3b46} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34074) (comment: 03363_join_multiple_swap.gen.sql) (in query: DROP DATABASE IF EXISTS test_dqc1tc78 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:37:38.320711 [ 2824 ] {f77ef659-4f2b-44dd-bd69-80a06a5e3b46} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:39.278104 [ 3816 ] {9d71c215-c245-4267-8001-b22666764fd7} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41652) (comment: 00926_zookeeper_adaptive_index_granularity_replicated_merge_tree_long.sql) (query 30, line 68) (in query: CREATE TABLE four_rows_per_granule1 ( p Date, k UInt64, v1 UInt64, v2 Int64 ) ENGINE ReplicatedMergeTree('/clickhouse/tables/{database}/test_00926/four_rows_in_granule', '1') PARTITION BY toYYYYMM(p) ORDER BY k SETTINGS index_granularity_bytes = 110, min_index_granularity_bytes = 100, write_final_mark = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1419: Coordination::ZooKeeper::create(String const&, String const&, bool, bool, std::vector> const&, std::function) @ 0x0000000032827f0e 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1203: zkutil::ZooKeeper::asyncTryCreateNoThrow(String const&, String const&, int) @ 0x000000003275f57e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:864: DB::StorageReplicatedMergeTree::createNewZooKeeperNodesAttempt() const @ 0x00000000305a6d43 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:845: DB::StorageReplicatedMergeTree::createNewZooKeeperNodes(DB::ZooKeeperRetriesInfo const&) const @ 0x000000003059cb9d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:626: 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&) @ 0x0000000030597510 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:37:39.308761 [ 3816 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327c068d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a9ea2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x0000000032824606 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1419: Coordination::ZooKeeper::create(String const&, String const&, bool, bool, std::vector> const&, std::function) @ 0x0000000032827f0e 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1203: zkutil::ZooKeeper::asyncTryCreateNoThrow(String const&, String const&, int) @ 0x000000003275f57e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:864: DB::StorageReplicatedMergeTree::createNewZooKeeperNodesAttempt() const @ 0x00000000305a6d43 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:845: DB::StorageReplicatedMergeTree::createNewZooKeeperNodes(DB::ZooKeeperRetriesInfo const&) const @ 0x000000003059cb9d 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:626: 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&) @ 0x0000000030597510 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, 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&) @ 0x00000000311cef49 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], 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&) @ 0x00000000311cecb4 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c89ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303d517f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc88fe8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:37:39.913949 [ 3461 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_102_102_0_635} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:39.952561 [ 3461 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_102_102_0_635} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:39.953709 [ 3461 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_102_102_0_635}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:40.021277 [ 3467 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_26_26_0_672} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:40.296210 [ 3467 ] {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_26_26_0_672} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:40.297438 [ 3467 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9::-1_26_26_0_672}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002dea55ca 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031021c89 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310209d9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003123e9df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:41.189545 [ 6951 ] {f87d2d00-855c-4735-8dc3-29e51dfd7383} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:36188, local: [::1]:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36188) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:41.190875 [ 4142 ] {65417cf3-e7d4-443b-a6e9-5cb9741e188e} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38910) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:41.200331 [ 6951 ] {f87d2d00-855c-4735-8dc3-29e51dfd7383} 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]:36188). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316adca3 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:41.200712 [ 4142 ] {65417cf3-e7d4-443b-a6e9-5cb9741e188e} 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]:38910). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:41.204500 [ 6951 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:36188, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:41.216885 [ 4142 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:41.454368 [ 46285 ] {bc86dfb6-5d45-4cba-a9b5-82d63d199c82} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39030, local: [::1]:9000). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39030) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:41.457477 [ 46285 ] {bc86dfb6-5d45-4cba-a9b5-82d63d199c82} 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]:39030). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316c3440 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316adca3 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:41.460068 [ 46285 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39030, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023cabc38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cac895 6. DB::ReadBuffer::next() @ 0x0000000017e75832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5378 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:42.205600 [ 6024 ] {d60f7e0a-8dda-4ffa-8903-2022e339cf17} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39140) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: INSERT INTO alter_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(100000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:42.211712 [ 6024 ] {d60f7e0a-8dda-4ffa-8903-2022e339cf17} 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]:39140). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316add47 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 12. ? @ 0x00007f9c53164ac3 13. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:42.214200 [ 6024 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316e1740 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316d5a64 5. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000316dfb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031820feb 7. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316ad9e0 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:43.068203 [ 2827 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5641 similar messages) 2025.07.13 02:37:45.240389 [ 6024 ] {4d8ca534-c57f-45f4-8dcc-93be7e09a7a4} executeQuery: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39418) (comment: 01356_wrong_filter-type_bug.sql) (query 2, line 3) (in query: CREATE TABLE t0 (`c0` String, `c1` Int32 CODEC(NONE), `c2` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 21870, min_bytes_for_wide_part = 8247847, ratio_of_defaults_for_sparse_serialization = 0.7577198147773743, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 7598510, compact_parts_max_bytes_to_buffer = 139010970, compact_parts_max_granules_to_buffer = 57, compact_parts_merge_max_bytes_to_prefetch_part = 26077922, merge_max_block_size = 17893, 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 = 1, index_granularity_bytes = 16470801, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 27016, primary_key_compress_block_size = 74198, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:45.272412 [ 6024 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:47.714057 [ 6024 ] {1d1ed2fb-63cb-4826-81c4-d472fb23ef25} executeQuery: Code: 141. DB::Exception: Illegal SAMPLE: table test_7.numbers1 (7c844e35-5203-46a3-8d3e-34df8605af4d) doesn't support sampling: Child table: test_7.numbers1 (7c844e35-5203-46a3-8d3e-34df8605af4d). (SAMPLING_NOT_SUPPORTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39474) (comment: 00578_merge_table_sampling.sql) (query 5, line 7) (in query: SELECT * FROM merge(currentDatabase(), '^numbers\\d+$') SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageMerge.cpp:660: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000003051bedf 6. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000003051491d 7. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000003052a7c7 8. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228d4bc 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003228c797 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289cb2 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:37:47.732756 [ 6024 ] {} TCPHandler: Code: 141. DB::Exception: Illegal SAMPLE: table test_7.numbers1 (7c844e35-5203-46a3-8d3e-34df8605af4d) doesn't support sampling: Child table: test_7.numbers1 (7c844e35-5203-46a3-8d3e-34df8605af4d). (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Storages/StorageMerge.cpp:660: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000003051bedf 6. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000003051491d 7. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000003052a7c7 8. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228d4bc 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003228c797 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032289cb2 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003216ddf0 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d42e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd705f3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd701e6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 23. ? @ 0x00007f9c53164ac3 24. ? @ 0x00007f9c531f6850 2025.07.13 02:37:48.602560 [ 6024 ] {d336dde6-b012-4cf9-a5b9-5930c5f32b49} executeQuery: Code: 57. DB::Exception: Table test_7.numbers2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39474) (comment: 00578_merge_table_sampling.sql) (query 9, line 13) (in query: CREATE TABLE numbers2 ENGINE = MergeTree ORDER BY intHash32(number) SAMPLE BY intHash32(number) SETTINGS index_granularity = 52739, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.378233939409256, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 349927604, compact_parts_max_bytes_to_buffer = 7450090, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 4110395, merge_max_block_size = 6177, old_parts_lifetime = 480., 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 = 10737418240, index_granularity_bytes = 28741589, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 98, 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 = 60875, primary_key_compress_block_size = 19870, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT number FROM numbers(1000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:48.616543 [ 6024 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.numbers2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.116166 [ 46286 ] {815b67a1-ddbe-4d73-8c75-696b4140c784} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35820). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35820) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.124477 [ 46286 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35820). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.452943 [ 34260 ] {c1e3d12a-14a2-47b9-99c8-d66637f43f3d} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36030). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36030) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.458685 [ 34260 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36030). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.688917 [ 32979 ] {7482d3aa-1852-412a-ba69-27cebbf7a394} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35890). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35890) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.775941 [ 32979 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35890). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.789869 [ 57044 ] {b96aea8a-0405-4908-adcd-7c64fcb61411} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35980). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35980) (comment: 00991_system_parts_race_condition_long.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:49.798653 [ 57044 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35980). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0931 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c265d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:37:50.552137 [ 5380 ] {1118bdff-4596-4854-9169-5058498feea4} PushingToViews: Failed to push block to view test_13.view (6b8a7bfb-a964-43df-9e81-389b4a564333), Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp'] 2025.07.13 02:37:50.743267 [ 5380 ] {1118bdff-4596-4854-9169-5058498feea4} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36200) (comment: 02993_lazy_index_loading.sql) (query 4, line 5) (in query: INSERT INTO test SELECT randomString(1000) FROM numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:50.771707 [ 5380 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `block_timestamp` in scope WITH (SELECT toDateTime('1970-01-01 00:00:00')) AS default_timestamp SELECT maxState(CAST(block_timestamp, 'Nullable(DateTime(\'UTC\'))')) AS block_timestamp, argMaxState(CAST(block_hash, 'Nullable(FixedString(32))'), insertion_time) AS block_hash, argMaxState(CAST(block_number, 'Nullable(UInt256)'), insertion_time) AS block_number, argMaxState(CAST(deployer, 'Nullable(FixedString(20))'), insertion_time) AS deployer, address, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS name, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS symbol, argMaxState(CAST(NULL, 'Nullable(UInt8)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS decimals, argMaxState(CAST(true, 'Nullable(Boolean)'), insertion_time) AS is_proxy, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS blacklist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS whitelist_flags, argMaxState(CAST('[]', 'Array(Nullable(String))'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS detected_standards, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS amended_type, argMaxState(CAST(NULL, 'Nullable(String)'), CAST(default_timestamp, 'DateTime(\'UTC\')')) AS comment, groupUniqArrayState('tokens_proxy_deployments') AS _sources, maxState(insertion_time) AS _updated_at, argMaxState(true, CAST(default_timestamp, 'DateTime(\'UTC\')')) AS _active FROM test_13.test WHERE insertion_time > toDateTime('2024-03-14 11:38:09') GROUP BY address. Maybe you meant: ['block_timestamp']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc34c16 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd6fb42 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef98cb 22. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031efe184 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dce8754 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dceada7 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec917 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 2025.07.13 02:37:50.926305 [ 3641 ] {} test_11.alter_table (1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:37:51.572239 [ 6024 ] {6e80c06c-682f-4f80-90e7-5e5ae3cc4b39} executeQuery: Code: 215. DB::Exception: Column test_lol5w934.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count(), quantile(0.9)(price) OVER () AS price_quantile FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > price_quantile. (NOT_AN_AGGREGATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42318) (comment: 03143_window_functions_qualify_validation.sql) (query 3, line 22) (in query: SELECT count(), (quantile(0.9)(price) OVER ()) AS price_quantile FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > price_quantile;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca6125 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cca464d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc06700 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:37:51.594860 [ 6024 ] {} TCPHandler: Code: 215. DB::Exception: Column test_lol5w934.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count(), quantile(0.9)(price) OVER () AS price_quantile FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > price_quantile. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca6125 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cca464d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc06700 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:37:51.786003 [ 34273 ] {172a5ffb-0590-4f42-9ef6-af0a41faf048} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42352) (comment: 03358_lambda_resolution_segfault_analyzer.sql) (query 2, line 2) (in query: WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc54899 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05415 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:37:51.816753 [ 6024 ] {5749924f-ed77-4f22-8eb4-e989f020c146} executeQuery: Code: 215. DB::Exception: Column test_lol5w934.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count() FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > quantile(0.9)(price) OVER (). (NOT_AN_AGGREGATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42318) (comment: 03143_window_functions_qualify_validation.sql) (query 4, line 24) (in query: SELECT count() FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > (quantile(0.9)(price) OVER ());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca6125 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cca464d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc06700 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:37:51.818056 [ 34273 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.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&&) @ 0x000000002cc66617 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc11ef5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc54899 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc05415 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:37:51.863606 [ 6024 ] {} TCPHandler: Code: 215. DB::Exception: Column test_lol5w934.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count() FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > quantile(0.9)(price) OVER (). (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca6125 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cca56c5 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cca464d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc06700 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 26. ? @ 0x00007f9c53164ac3 27. ? @ 0x00007f9c531f6850 2025.07.13 02:37:52.906514 [ 3641 ] {} DatabaseCatalog: Cannot drop table test_11.alter_table (1c382f8c-bbb4-4fd6-80e7-08eb5eedc8c9). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc3f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cbaf4a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cb9def 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cc6347 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d604fd1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d613364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002879e734 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x000000002879e51b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:54.119950 [ 57039 ] {571d87cc-10fb-4ceb-bad4-f2faf5bbd1a7} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42390) (comment: 00550_join_insert_select.sh) (query 9, line 12) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY INNER JOIN test3_00550 USING (id) SETTINGS any_join_distinct_right_table_keys=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:54.126673 [ 57039 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:54.272452 [ 57039 ] {9574bb21-1ed8-40b7-81e6-c2b32da3a64e} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42390) (comment: 00550_join_insert_select.sh) (query 10, line 13) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY LEFT OUTER JOIN test3_00550 USING (id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:54.297113 [ 57039 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1432f 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb2dfdf 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dcec124 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf14fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:55.046952 [ 6022 ] {fcffabb9-cf6f-4495-b898-c8e0463df12c} executeQuery: Code: 57. DB::Exception: Table test_9.nested already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39534) (comment: 00554_nested_and_table_engines.sql) (query 30, line 51) (in query: CREATE TABLE nested (`x` UInt8, `n` Nested(a UInt64, b String)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 45241, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 273591652, compact_parts_max_granules_to_buffer = 221, compact_parts_merge_max_bytes_to_prefetch_part = 24335407, merge_max_block_size = 1795, old_parts_lifetime = 145., 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 = 8092550697, index_granularity_bytes = 8311434, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 65493, primary_key_compress_block_size = 23679, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:55.058734 [ 6022 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.nested already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:56.673230 [ 3766 ] {0fe7508b-c422-45e8-bcf5-6467dd2cf661} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47092) (comment: 00975_recursive_materialized_view.sql) (in query: DROP DATABASE IF EXISTS test_0ehxnsuu SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:37:56.675978 [ 3766 ] {0fe7508b-c422-45e8-bcf5-6467dd2cf661} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:37:56.805504 [ 7056 ] {d51c6016-c8a7-4225-b566-40747f119b15} executeQuery: Code: 15. DB::Exception: Column time in table test_1.sometable (50ece466-a1ab-40a1-a36f-2435bedaab40) specified more than once. (DUPLICATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42504) (comment: 01032_duplicate_column_insert_query.sql) (query 5, line 15) (in query: INSERT INTO sometable (date, time, value, time) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:239: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000002dce69da 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002dce5975 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf106e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:56.815177 [ 7056 ] {} TCPHandler: Code: 15. DB::Exception: Column time in table test_1.sometable (50ece466-a1ab-40a1-a36f-2435bedaab40) specified more than once. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874d76f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:239: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000002dce69da 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000002dce5975 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf106e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:37:58.520040 [ 5971 ] {4d5fd0b2-397b-4fb1-8115-f98b241499d3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42572) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:37:58.544295 [ 5971 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1ca38f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8801 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002beb7edf 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d494601 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de2e90c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:38:00.401453 [ 46285 ] {68e7c83a-4041-4da3-8798-6dbf5dec9580} executeQuery: Code: 57. DB::Exception: Table test_dtlnku4t.nullable_set_index already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42562) (comment: 00907_set_index_with_nullable_and_low_cardinality.sql) (query 12, line 14) (in query: CREATE TABLE nullable_set_index (`a` UInt64, `b` Nullable(String), INDEX b_index b TYPE set(1) GRANULARITY 8192) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 9599, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 30, min_bytes_for_full_part_storage = 481600292, compact_parts_max_bytes_to_buffer = 344708545, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 22572485, merge_max_block_size = 13390, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6422287976, index_granularity_bytes = 5655543, 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 = 54286, primary_key_compress_block_size = 86792, 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:38:00.427140 [ 46285 ] {} TCPHandler: Code: 57. DB::Exception: Table test_dtlnku4t.nullable_set_index already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8c69c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7e08c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94e05 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 16. ? @ 0x00007f9c53164ac3 17. ? @ 0x00007f9c531f6850 2025.07.13 02:38:00.486590 [ 34260 ] {5918556039914025b4f0cdfaeb686a1a} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:45494). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:38:00.493215 [ 34260 ] {5918556039914025b4f0cdfaeb686a1a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:45494). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45494) (in query: select 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:38:00.504217 [ 34260 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:45494). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cad667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023cb0591 5. DB::WriteBuffer::next() @ 0x0000000017cd6383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316d35a3 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c2192 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 2025.07.13 02:38:06.348951 [ 34260 ] {b172b90b-64d6-414b-8be1-dc59291a933c} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47964) (comment: 02455_improve_feedback_when_replacing_partition_with_different_primary_key.sql) (query 4, line 4) (in query: ALTER TABLE test_b REPLACE PARTITION '0' FROM test_a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7770: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3dc62 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003120c749 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e8ac 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:38:06.355182 [ 34260 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7770: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030d3dc62 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003120c749 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000030d0e8ac 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4cf63 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc49bd1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:38:07.921862 [ 73227 ] {f8783a27-4f01-406c-a9de-7e867166621e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47982) (comment: 00700_decimal_empty_aggregates.sql) (query 12, line 27) (in query: SELECT uniqUpTo(10)(a), uniqUpTo(10)(b), uniqUpTo(10)(c) FROM decimal WHERE a >= 0 AND a < 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:38:07.948576 [ 73227 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:38:08.659879 [ 6022 ] {2d56f5ea-b113-4025-bd2f-6c0e42a13b95} 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.3.20372.altinityantalya (altinity build)) (from [::1]:48138) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f41b75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:38:08.668598 [ 6022 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f41b75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 2025.07.13 02:38:09.359832 [ 73221 ] {33ed308c-b76d-4475-848d-1996b4ca5d26} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48074) (comment: 00508_materialized_view_to.sql) (query 16, line 30) (in query: DROP DATABASE test_9), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb6fe2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:38:09.364689 [ 73221 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x000000002879cfdc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb6fe2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:38:11.013516 [ 32979 ] {5b2989ce-d2bb-427c-809e-cd7961666183} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitAnd is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1, line 1) (in query: SELECT BIT_AND([]);) 2025.07.13 02:38:11.032738 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitAnd is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:11.159045 [ 32979 ] {fbd124b6-93a6-433f-9366-8f528c7f3c49} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitOr is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 2, line 2) (in query: SELECT BIT_OR([]);) 2025.07.13 02:38:11.184851 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitOr is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:11.294994 [ 32979 ] {c1caf060-b034-49f6-b68e-7048004b4f50} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitXor is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 3, line 3) (in query: SELECT BIT_XOR([]);) 2025.07.13 02:38:11.328381 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitXor is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:11.452784 [ 32979 ] {232d48a8-9d91-4ee9-aa58-872e150dd75b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function BLAKE3: In scope SELECT BLAKE3([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 4, line 4) (in query: SELECT BLAKE3([]);) 2025.07.13 02:38:11.457485 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function BLAKE3: In scope SELECT BLAKE3([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:11.599633 [ 32979 ] {65055db8-721f-49f0-81a8-146a0dac803b} executeQuery: Code: 43. DB::Exception: Cannot apply function lengthUTF8 to Array argument: In scope SELECT CHARACTER_LENGTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH([]);) 2025.07.13 02:38:11.627778 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function lengthUTF8 to Array argument: In scope SELECT CHARACTER_LENGTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:11.844394 [ 32979 ] {30002803-1654-4e27-a16f-bfcce7150d0f} executeQuery: Code: 43. DB::Exception: Cannot apply function lengthUTF8 to Array argument: In scope SELECT CHAR_LENGTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH([]);) 2025.07.13 02:38:11.884640 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function lengthUTF8 to Array argument: In scope SELECT CHAR_LENGTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:11.989497 [ 32979 ] {444e8f71-6e91-4aa4-a693-756d8d27b4c3} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 7, line 8) (in query: SELECT COVAR_POP([]);) 2025.07.13 02:38:12.003613 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:12.176249 [ 32979 ] {753273eb-7879-4afa-87db-f886766f0d7c} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 8, line 9) (in query: SELECT COVAR_SAMP([]);) 2025.07.13 02:38:12.183702 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:12.253759 [ 32979 ] {e50e6f3c-b4f2-4a16-9e1f-84c84ca78b96} executeQuery: Code: 43. DB::Exception: Cannot apply function CRC32 to Array argument: In scope SELECT CRC32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 9, line 10) (in query: SELECT CRC32([]);) 2025.07.13 02:38:12.264681 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function CRC32 to Array argument: In scope SELECT CRC32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:12.375593 [ 32979 ] {f567f744-331e-461f-a626-c205e36755c9} executeQuery: Code: 43. DB::Exception: Cannot apply function CRC32IEEE to Array argument: In scope SELECT CRC32IEEE([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 10, line 11) (in query: SELECT CRC32IEEE([]);) 2025.07.13 02:38:12.389456 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function CRC32IEEE to Array argument: In scope SELECT CRC32IEEE([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:12.493299 [ 32979 ] {7158abfc-c92e-415a-916d-34c9b5e1d15c} executeQuery: Code: 43. DB::Exception: Cannot apply function CRC64 to Array argument: In scope SELECT CRC64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 11, line 12) (in query: SELECT CRC64([]);) 2025.07.13 02:38:12.500382 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function CRC64 to Array argument: In scope SELECT CRC64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:12.620939 [ 32979 ] {e77e2ad2-c6c1-4b84-ac31-0c72c6137b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT DATABASE([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 12, line 13) (in query: SELECT DATABASE([]);) 2025.07.13 02:38:12.624486 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT DATABASE([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:12.823955 [ 32979 ] {d19d4b4d-a0bb-41e7-b277-1bc72d754ec7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate: In scope SELECT DATE([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 13, line 14) (in query: SELECT DATE([]);) 2025.07.13 02:38:12.848267 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate: In scope SELECT DATE([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:12.963880 [ 32979 ] {f230533b-9526-4de2-a2ea-3acbd2948363} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 14, line 15) (in query: SELECT DATE_DIFF([]);) 2025.07.13 02:38:12.971754 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:13.081971 [ 32979 ] {d7450e76-d757-4199-8fe6-3b3c4a6e05e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_FORMAT([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 15, line 16) (in query: SELECT DATE_FORMAT([]);) 2025.07.13 02:38:13.100406 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_FORMAT([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:13.168764 [ 32979 ] {bb793425-1b54-4484-98b9-cb8c5b6f1279} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_TRUNC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 16, line 17) (in query: SELECT DATE_TRUNC([]);) 2025.07.13 02:38:13.173928 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_TRUNC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:13.317183 [ 32979 ] {e5ca719d-c1b0-40e7-bfb7-ca3702d3fee2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAY([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 17, line 18) (in query: SELECT DAY([]);) 2025.07.13 02:38:13.326306 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAY([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:13.459628 [ 32979 ] {fa0a1a54-54c0-4ab9-b070-4a11f60e4503} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFMONTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 18, line 19) (in query: SELECT DAYOFMONTH([]);) 2025.07.13 02:38:13.474091 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFMONTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:13.592548 [ 32979 ] {163855b7-cb5c-4635-a701-c1a355bf470a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT DAYOFWEEK([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 19, line 20) (in query: SELECT DAYOFWEEK([]);) 2025.07.13 02:38:13.599003 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT DAYOFWEEK([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:13.682647 [ 32979 ] {8d6fbe7d-ed24-460f-972a-35cffd603f98} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFYEAR([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 20, line 21) (in query: SELECT DAYOFYEAR([]);) 2025.07.13 02:38:13.697144 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFYEAR([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:13.761439 [ 32979 ] {7e26aaf8-092a-4d85-8053-6799507571cb} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT FORMAT_BYTES([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES([]);) 2025.07.13 02:38:13.771675 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT FORMAT_BYTES([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:13.821792 [ 32979 ] {ad819aaa-f482-4b1e-b8e4-05835321e6ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT FQDN([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 22, line 23) (in query: SELECT FQDN([]);) 2025.07.13 02:38:13.828059 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT FQDN([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:13.859606 [ 6024 ] {3297678a-29e2-4920-89f1-e05ff9664749} executeQuery: Code: 36. DB::Exception: Last argument (count) for function widthBucket cannot be 0.: while executing 'FUNCTION widthBucket(__table1.operand :: 0, __table1.low :: 1, __table1.high :: 2, __table1.count : 3) -> widthBucket(__table1.operand, __table1.low, __table1.high, __table1.count) UInt64 : 7'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 5, line 14) (in query: -- zero is not valid for count SELECT operand, low, high, count, WIDTH_BUCKET(operand, low, high, count) FROM mytable WHERE count = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, unsigned long) const @ 0x0000000020dd7c8d 6. unsigned long DB::FunctionWidthBucket::calculate(double, double, double, unsigned long) const @ 0x0000000020dd782c 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd4abc 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd06ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 2025.07.13 02:38:13.866738 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: Last argument (count) for function widthBucket cannot be 0.: while executing 'FUNCTION widthBucket(__table1.operand :: 0, __table1.low :: 1, __table1.high :: 2, __table1.count : 3) -> widthBucket(__table1.operand, __table1.low, __table1.high, __table1.count) UInt64 : 7'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, unsigned long) const @ 0x0000000020dd7c8d 6. unsigned long DB::FunctionWidthBucket::calculate(double, double, double, unsigned long) const @ 0x0000000020dd782c 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd4abc 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd06ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd5fce 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9cf7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d6320b5 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d62f8a7 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dc5bc9 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288dedd7 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003180789a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x0000000031838c8e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000318241bf 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031823385 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 25. ? @ 0x00007f9c53164ac3 26. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:38:13.926447 [ 32979 ] {50db7f52-726d-4068-aeb9-4121288f9a73} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT FROM_BASE64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 23, line 24) (in query: SELECT FROM_BASE64([]);) 2025.07.13 02:38:13.937642 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT FROM_BASE64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:13.981545 [ 6024 ] {dc2f6d15-3f8b-4e21-be6f-70515a6bb56a} executeQuery: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, 10, nan, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 6, line 16) (in query: -- operand, low and high cannot be NaN SELECT WIDTH_BUCKET(0, 10, NaN, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd5f17 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:13.996364 [ 34260 ] {1124d621-42ce-4132-a07e-cd74fd27111d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34168) (comment: 03205_parallel_window_finctions_and_column_sparse_bug.sql) (in query: DROP DATABASE IF EXISTS test_lppemakb SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:38:13.998102 [ 34260 ] {1124d621-42ce-4132-a07e-cd74fd27111d} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:38:14.005336 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, 10, nan, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd5f17 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.096615 [ 32979 ] {a03a54b2-0d42-4d9c-9275-c8390e865d22} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'days' to function 'fromDaysSinceYearZero'. Expected: Integer, got: Array(Nothing): In scope SELECT FROM_DAYS([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 24, line 25) (in query: SELECT FROM_DAYS([]);) 2025.07.13 02:38:14.103142 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'days' to function 'fromDaysSinceYearZero'. Expected: Integer, got: Array(Nothing): In scope SELECT FROM_DAYS([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.103729 [ 7056 ] {ff75ad01-1b49-40e5-80dd-930acea06cd7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34184) (comment: 03205_parallel_window_finctions_and_column_sparse_bug.sql) (in query: DROP DATABASE IF EXISTS test_lppemakb SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:38:14.108236 [ 7056 ] {ff75ad01-1b49-40e5-80dd-930acea06cd7} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:38:14.116162 [ 6024 ] {0ce9e770-6dd9-4030-9c18-cfb367b8ae43} executeQuery: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(nan, 0, 10, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 7, line 18) (in query: SELECT WIDTH_BUCKET(NaN, 0, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd5f17 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.159397 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(nan, 0, 10, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd5f17 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.173075 [ 32979 ] {9013fb5c-ad2e-4acf-a245-0ff35e52df39} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 1. Should be integer: In scope SELECT FROM_UNIXTIME([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 25, line 26) (in query: SELECT FROM_UNIXTIME([]);) 2025.07.13 02:38:14.180115 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 1. Should be integer: In scope SELECT FROM_UNIXTIME([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.246922 [ 6024 ] {7da5f764-7e53-40b0-80e1-4234da67856f} executeQuery: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, nan, 10, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 8, line 19) (in query: SELECT WIDTH_BUCKET(0, NaN, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd5f17 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.250660 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: The first three arguments (operand, low, high) cannot be NaN in function widthBucket: In scope SELECT WIDTH_BUCKET(0, nan, 10, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd5f17 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.261114 [ 32979 ] {a2f915d5-9be9-4276-8a9a-0e76a458722c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT HOUR([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 26, line 27) (in query: SELECT HOUR([]);) 2025.07.13 02:38:14.271091 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT HOUR([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.341041 [ 32979 ] {d864e6a0-569e-4543-8549-5caeb91d52df} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNum: In scope SELECT INET6_ATON([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 27, line 28) (in query: SELECT INET6_ATON([]);) 2025.07.13 02:38:14.365904 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNum: In scope SELECT INET6_ATON([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.406439 [ 6024 ] {23277aed-eba6-4cc4-a4b1-f5bba4c64d06} executeQuery: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, -inf, 10, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 9, line 20) (in query: -- low and high cannot be Inf SELECT WIDTH_BUCKET(1, -Inf, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd60d7 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.424177 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, -inf, 10, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd60d7 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.456041 [ 32979 ] {068c0915-53e6-4ab2-b0ef-c7ec9dfd720e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT INET6_NTOA([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 28, line 29) (in query: SELECT INET6_NTOA([]);) 2025.07.13 02:38:14.471766 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT INET6_NTOA([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.512734 [ 6024 ] {48450483-f229-4c7a-a683-c99d637fd35c} executeQuery: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, 0, inf, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 10, line 22) (in query: -- low and high cannot be Inf SELECT WIDTH_BUCKET(1, 0, Inf, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd60d7 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.515203 [ 6024 ] {} TCPHandler: Code: 36. DB::Exception: The second and third arguments (low, high) cannot be Inf function widthBucket: In scope SELECT WIDTH_BUCKET(1, 0, inf, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. std::optional DB::FunctionWidthBucket::checkArguments(double, double, double, char8_t) const @ 0x0000000020dd60d7 6. unsigned short DB::FunctionWidthBucket::calculate(double, double, double, char8_t) const @ 0x0000000020dd59a8 7. COW::immutable_ptr DB::FunctionWidthBucket::executeForResultType(std::vector> const&, unsigned long) const @ 0x0000000020dd1870 8. DB::FunctionWidthBucket::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dd0661 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbe3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acd610e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c9f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc93f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acc9c29 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accc6fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002accdd10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cd32 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 2025.07.13 02:38:14.566796 [ 32979 ] {f5d486f2-54a1-4704-a463-a2b619670134} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNum: In scope SELECT INET_ATON([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 29, line 30) (in query: SELECT INET_ATON([]);) 2025.07.13 02:38:14.588341 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNum: In scope SELECT INET_ATON([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.736937 [ 32979 ] {4e715615-7e1f-4ddb-918a-938856e0c949} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT INET_NTOA([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 30, line 31) (in query: SELECT INET_NTOA([]);) 2025.07.13 02:38:14.760180 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT INET_NTOA([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:14.862863 [ 32979 ] {7fa7d361-4dc4-4514-bb71-20245674afd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv4CIDRToRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange([]);) 2025.07.13 02:38:14.877872 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv4CIDRToRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:14.988912 [ 32979 ] {0ea6658f-9845-4a04-94ca-434e0e227076} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 32, line 33) (in query: SELECT IPv4NumToString([]);) 2025.07.13 02:38:14.996959 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.142347 [ 32979 ] {6a0fdf34-25fc-4fd3-8234-b11e6cfe96bb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4NumToStringClassC, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToStringClassC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC([]);) 2025.07.13 02:38:15.157675 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4NumToStringClassC, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToStringClassC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.242896 [ 32979 ] {52da231a-91ee-447c-8037-aa44ef75d786} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNum: In scope SELECT IPv4StringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum([]);) 2025.07.13 02:38:15.246093 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNum: In scope SELECT IPv4StringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.436309 [ 32979 ] {ddae1690-ac2a-4d98-a742-6300895e92f5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNumOrDefault: In scope SELECT IPv4StringToNumOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault([]);) 2025.07.13 02:38:15.443577 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNumOrDefault: In scope SELECT IPv4StringToNumOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.517076 [ 32979 ] {29e6a994-628e-4d22-9fbf-ed467e24d81b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNumOrNull: In scope SELECT IPv4StringToNumOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull([]);) 2025.07.13 02:38:15.522704 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4StringToNumOrNull: In scope SELECT IPv4StringToNumOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.610584 [ 32979 ] {a7fd15a2-6c94-4eef-a256-325155418f4a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4ToIPv6: In scope SELECT IPv4ToIPv6([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6([]);) 2025.07.13 02:38:15.632781 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv4ToIPv6: In scope SELECT IPv4ToIPv6([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.674678 [ 32979 ] {c36d3f89-79e7-4a07-a145-0fa06f7c1afc} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv6CIDRToRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange([]);) 2025.07.13 02:38:15.700188 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv6CIDRToRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:15.736244 [ 32979 ] {bd4db234-e9db-4f6f-bed5-c9207a50c3a7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT IPv6NumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 39, line 40) (in query: SELECT IPv6NumToString([]);) 2025.07.13 02:38:15.740923 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT IPv6NumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.766241 [ 32979 ] {f779168b-e7e3-4fb1-af13-e811bcc134d8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNum: In scope SELECT IPv6StringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum([]);) 2025.07.13 02:38:15.769953 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNum: In scope SELECT IPv6StringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:15.954722 [ 32979 ] {a494b261-a849-4146-98fb-8e909ddd0002} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNumOrDefault: In scope SELECT IPv6StringToNumOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault([]);) 2025.07.13 02:38:15.969924 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNumOrDefault: In scope SELECT IPv6StringToNumOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:16.017531 [ 32979 ] {3639a2ee-b0b5-49cc-8707-61b45d060676} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNumOrNull: In scope SELECT IPv6StringToNumOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull([]);) 2025.07.13 02:38:16.024736 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function IPv6StringToNumOrNull: In scope SELECT IPv6StringToNumOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:16.119363 [ 6024 ] {d4de78a7-0926-48cd-af56-54798c921a5f} executeQuery: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int8.: In scope SELECT WIDTH_BUCKET(1, 2, 3, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 18, line 34) (in query: SELECT WIDTH_BUCKET(1, 2, 3, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0d83 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.127411 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int8.: In scope SELECT WIDTH_BUCKET(1, 2, 3, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0d83 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.166171 [ 32979 ] {198deeb9-3c68-4f6c-b26d-3c281240f47d} executeQuery: Code: 42. DB::Exception: Function JSONAllPaths requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONAllPaths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 43, line 44) (in query: SELECT JSONAllPaths([]);) 2025.07.13 02:38:16.187012 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONAllPaths requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONAllPaths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:16.237783 [ 6024 ] {6ba51f45-7a8a-42b2-b361-8de17b8de68e} executeQuery: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Float64.: In scope SELECT WIDTH_BUCKET(1, 2, 3, 1.3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 19, line 35) (in query: SELECT WIDTH_BUCKET(1, 2, 3, 1.3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0d83 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.242214 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Float64.: In scope SELECT WIDTH_BUCKET(1, 2, 3, 1.3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0d83 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.269218 [ 32979 ] {24e1a55c-f21a-4e18-94ec-7b0fe65c6745} executeQuery: Code: 42. DB::Exception: Function JSONAllPathsWithTypes requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONAllPathsWithTypes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes([]);) 2025.07.13 02:38:16.282604 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONAllPathsWithTypes requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONAllPathsWithTypes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:16.357978 [ 32979 ] {05b9b046-80e2-46f3-884f-6d4023d94028} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Array(Nothing): In scope SELECT JSONArrayLength([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 45, line 46) (in query: SELECT JSONArrayLength([]);) 2025.07.13 02:38:16.382513 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Array(Nothing): In scope SELECT JSONArrayLength([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:16.420617 [ 6024 ] {b519515b-6b95-4a3a-8eb4-6bbf16e8d8da} executeQuery: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET('a', 1, 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 20, line 36) (in query: SELECT WIDTH_BUCKET('a', 1, 2, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0c18 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.436611 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET('a', 1, 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0c18 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.491484 [ 32979 ] {c689457a-fa73-49fc-b323-2cf120e9d1f3} executeQuery: Code: 42. DB::Exception: Function JSONDynamicPaths requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONDynamicPaths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths([]);) 2025.07.13 02:38:16.509657 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONDynamicPaths requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONDynamicPaths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:16.564402 [ 6024 ] {ea252af2-2d0a-409b-bb93-14ef71a707c0} executeQuery: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, toUInt128(42), 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 21, line 37) (in query: SELECT WIDTH_BUCKET(1, toUInt128(42), 2, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0c18 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.596600 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, toUInt128(42), 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0c18 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.702840 [ 32979 ] {f617380a-6cdf-4945-99ec-20b007635d56} executeQuery: Code: 42. DB::Exception: Function JSONDynamicPathsWithTypes requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONDynamicPathsWithTypes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes([]);) 2025.07.13 02:38:16.706634 [ 6024 ] {901ea5fa-c48a-4da9-8fe3-4c5cf7f89739} executeQuery: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, 2, toInt128(42), 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 22, line 38) (in query: SELECT WIDTH_BUCKET(1, 2, toInt128(42), 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0c18 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.756114 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: The first three arguments of function widthBucket must be a Int8, Int16, Int32, Int64, UInt8, UInt16, UInt32, UInt64, Float32 or Float64.: In scope SELECT WIDTH_BUCKET(1, 2, toInt128(42), 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0c18 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.775031 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONDynamicPathsWithTypes requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONDynamicPathsWithTypes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:16.881235 [ 32979 ] {40e7eaa8-27c6-44db-a1ef-e35212e05168} executeQuery: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 48, line 49) (in query: SELECT JSONExtract([]);) 2025.07.13 02:38:16.886781 [ 6024 ] {878bf3e5-220d-4259-abc3-abfff6624e3d} executeQuery: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int256.: In scope SELECT WIDTH_BUCKET(1, 2, 3, toInt256(42)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59766) (comment: 02581_width_bucket.sql) (query 23, line 39) (in query: SELECT WIDTH_BUCKET(1, 2, 3, toInt256(42));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0d83 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.902086 [ 6024 ] {} TCPHandler: Code: 43. DB::Exception: The last argument of function widthBucket must be UInt8, UInt16, UInt32 or UInt64, found Int256.: In scope SELECT WIDTH_BUCKET(1, 2, 3, toInt256(42)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. DB::FunctionWidthBucket::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020dd0d83 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbe934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002accf32b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002accfdde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3b900 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc10080 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc0eeff 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc56dcc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cc050cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cc02d09 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cc02331 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002ccaedb9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd6f458 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd6d01a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd713ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd70d65 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dcd61ef 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ad480 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 30. ? @ 0x00007f9c53164ac3 31. ? @ 0x00007f9c531f6850 2025.07.13 02:38:16.906449 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:17.035194 [ 32979 ] {1e791423-f82b-4f29-95c9-500eaa83c790} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractArrayRaw([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 49, line 50) (in query: SELECT JSONExtractArrayRaw([]);) 2025.07.13 02:38:17.041042 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractArrayRaw([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.188044 [ 32979 ] {a16035fb-7b42-4b5c-bad2-4faf8bde9bbb} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractBool([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 50, line 51) (in query: SELECT JSONExtractBool([]);) 2025.07.13 02:38:17.194007 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractBool([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.241976 [ 32979 ] {04f5c642-3aac-4d4c-8fdb-27d07cab2908} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractFloat([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 51, line 52) (in query: SELECT JSONExtractFloat([]);) 2025.07.13 02:38:17.245881 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractFloat([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.277461 [ 32979 ] {6df11ecd-b5fa-42b1-90ca-fa956fa3c4aa} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractInt([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 52, line 53) (in query: SELECT JSONExtractInt([]);) 2025.07.13 02:38:17.280636 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractInt([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.303124 [ 32979 ] {65ab967f-2821-4a9a-8026-4ab32a4ccf79} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeys([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 53, line 54) (in query: SELECT JSONExtractKeys([]);) 2025.07.13 02:38:17.306949 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeys([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.328558 [ 32979 ] {0d3aa135-bbd6-431e-93ee-65a7765a6a21} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues([]);) 2025.07.13 02:38:17.331920 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:17.380811 [ 32979 ] {fd752754-0009-4d54-8cf3-db7b21215d4f} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeysAndValuesRaw([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 55, line 56) (in query: SELECT JSONExtractKeysAndValuesRaw([]);) 2025.07.13 02:38:17.402281 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeysAndValuesRaw([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.425218 [ 32979 ] {fe827c17-0b5e-4f34-832b-1893acbfb0ff} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractRaw([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 56, line 57) (in query: SELECT JSONExtractRaw([]);) 2025.07.13 02:38:17.456960 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractRaw([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.548608 [ 32979 ] {71b1d2c3-ff82-4223-aeaf-dd1c4913f3bd} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 57, line 58) (in query: SELECT JSONExtractString([]);) 2025.07.13 02:38:17.553361 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.589994 [ 32979 ] {c5d878a2-8ad9-4062-b568-c4c11ca1bfec} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractUInt([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 58, line 59) (in query: SELECT JSONExtractUInt([]);) 2025.07.13 02:38:17.595229 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractUInt([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.632428 [ 32979 ] {47e5c780-5a93-4c44-b6fe-969802b69172} executeQuery: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONHas([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 59, line 60) (in query: SELECT JSONHas([]);) 2025.07.13 02:38:17.648763 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONHas([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.801509 [ 32979 ] {ad9210e9-2876-46c0-80d3-e30a957241bf} executeQuery: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONKey([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 60, line 61) (in query: SELECT JSONKey([]);) 2025.07.13 02:38:17.811391 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONKey([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.862952 [ 32979 ] {50d2d90f-085e-4f22-83a0-089ef30beee7} executeQuery: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONLength([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 61, line 62) (in query: SELECT JSONLength([]);) 2025.07.13 02:38:17.869787 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONLength([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.915786 [ 32979 ] {7ffa3cb1-bfca-46c2-9f5e-9c613e1efeee} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 62, line 63) (in query: SELECT JSONMergePatch([]);) 2025.07.13 02:38:17.919844 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:17.952573 [ 32979 ] {2408e837-c965-4faf-ba22-f62f04368f5a} executeQuery: Code: 42. DB::Exception: Function JSONSharedDataPaths requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONSharedDataPaths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths([]);) 2025.07.13 02:38:17.956536 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONSharedDataPaths requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONSharedDataPaths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:18.014958 [ 32979 ] {01fe7f22-50bb-4693-843d-238530f0d2e4} executeQuery: Code: 42. DB::Exception: Function JSONSharedDataPathsWithTypes requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONSharedDataPathsWithTypes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes([]);) 2025.07.13 02:38:18.031030 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONSharedDataPathsWithTypes requires argument with type JSON, got: Array(Nothing): In scope SELECT JSONSharedDataPathsWithTypes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:18.074042 [ 32979 ] {880a0591-7ea5-49b4-91d6-b2800360de12} executeQuery: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONType([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 65, line 66) (in query: SELECT JSONType([]);) 2025.07.13 02:38:18.080533 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONType([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:18.174073 [ 32979 ] {660290bd-e6f8-444a-8952-a048d81141b9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Array(Nothing): In scope SELECT JSON_ARRAY_LENGTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH([]);) 2025.07.13 02:38:18.177562 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Array(Nothing): In scope SELECT JSON_ARRAY_LENGTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:18.271725 [ 32979 ] {e1448d60-e207-4c6d-a833-09d154cb3b27} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 67, line 68) (in query: SELECT JSON_EXISTS([]);) 2025.07.13 02:38:18.277701 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:18.391320 [ 32979 ] {d8aa4dbd-9410-48aa-bf37-873a84144aab} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 68, line 69) (in query: SELECT JSON_QUERY([]);) 2025.07.13 02:38:18.395902 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:18.441222 [ 32979 ] {118bc8d2-52e0-470f-a4e3-b8609c516bd8} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 69, line 70) (in query: SELECT JSON_VALUE([]);) 2025.07.13 02:38:18.444344 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:18.473416 [ 32979 ] {604f0c9e-e173-4676-8bb0-b1b3806dff19} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT L1Distance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 70, line 71) (in query: SELECT L1Distance([]);) 2025.07.13 02:38:18.511671 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT L1Distance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:18.620918 [ 32979 ] {44a8aede-00c2-449e-888c-7195f96c4afb} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL1Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT L1Norm([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 71, line 72) (in query: SELECT L1Norm([]);) 2025.07.13 02:38:18.625600 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL1Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT L1Norm([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:18.693297 [ 32979 ] {51e7fd69-9707-4e19-9b11-7b4fe9fed78d} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Array(Nothing): In scope SELECT L1Normalize([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 72, line 73) (in query: SELECT L1Normalize([]);) 2025.07.13 02:38:18.700414 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Array(Nothing): In scope SELECT L1Normalize([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:18.742989 [ 32979 ] {1523fa62-4577-42fb-ae63-04f18c403447} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT L2Distance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 73, line 74) (in query: SELECT L2Distance([]);) 2025.07.13 02:38:18.804828 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT L2Distance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:18.837617 [ 32979 ] {59baea45-49a5-46b7-a7e1-c75939a679fe} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT L2Norm([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 74, line 75) (in query: SELECT L2Norm([]);) 2025.07.13 02:38:18.851988 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT L2Norm([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:18.893512 [ 32979 ] {7493000c-9163-45af-bc25-4f1f4a1e0c3a} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Array(Nothing): In scope SELECT L2Normalize([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 75, line 76) (in query: SELECT L2Normalize([]);) 2025.07.13 02:38:18.898646 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Array(Nothing): In scope SELECT L2Normalize([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:19.097170 [ 32979 ] {bd32e3be-12d5-4ac3-bde5-e4cd55b99255} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT L2SquaredDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance([]);) 2025.07.13 02:38:19.123823 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT L2SquaredDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:19.170617 [ 32979 ] {0a582aa4-33b7-429c-a53d-84ee99e957d1} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2SquaredNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT L2SquaredNorm([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm([]);) 2025.07.13 02:38:19.186087 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2SquaredNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT L2SquaredNorm([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:19.271899 [ 32979 ] {be490663-7b15-415e-a921-be178747950f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT LAST_DAY([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 78, line 79) (in query: SELECT LAST_DAY([]);) 2025.07.13 02:38:19.277239 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT LAST_DAY([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:19.405324 [ 32979 ] {43eff741-4edc-4b1d-9fb0-f0c2c569b798} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT LinfDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 79, line 80) (in query: SELECT LinfDistance([]);) 2025.07.13 02:38:19.410540 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT LinfDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:19.451659 [ 32979 ] {3ceb3cb6-f3c0-4283-b24b-6a276b238f9e} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLinfNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT LinfNorm([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 80, line 81) (in query: SELECT LinfNorm([]);) 2025.07.13 02:38:19.563479 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLinfNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT LinfNorm([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:19.684649 [ 32979 ] {a0c4bc8e-ba6a-419e-a289-5a23ddf2e82b} executeQuery: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Array(Nothing): In scope SELECT LinfNormalize([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 81, line 82) (in query: SELECT LinfNormalize([]);) 2025.07.13 02:38:19.704014 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Array(Nothing): In scope SELECT LinfNormalize([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:19.775955 [ 32979 ] {73bac08f-19c1-4b3e-8d8d-eb8fcfc4ae4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT LpDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 82, line 83) (in query: SELECT LpDistance([]);) 2025.07.13 02:38:19.786450 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT LpDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:19.876902 [ 32979 ] {ce47568d-4f5e-471c-82d4-8e803028fab5} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 83, line 84) (in query: SELECT LpNorm([]);) 2025.07.13 02:38:19.899894 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:19.967696 [ 32979 ] {d79c3a87-b216-4a40-9dc6-e9365e81d730} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT LpNormalize([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 84, line 85) (in query: SELECT LpNormalize([]);) 2025.07.13 02:38:19.975561 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT LpNormalize([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:20.119089 [ 32979 ] {a9376ca3-49dd-4517-ac11-585bc5229d19} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MACNumToString, expected UInt64: In scope SELECT MACNumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 85, line 86) (in query: SELECT MACNumToString([]);) 2025.07.13 02:38:20.142910 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MACNumToString, expected UInt64: In scope SELECT MACNumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.183325 [ 32979 ] {0aaf36fc-e6ef-4589-a979-e8b0a6d7c633} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MACStringToNum: In scope SELECT MACStringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 86, line 87) (in query: SELECT MACStringToNum([]);) 2025.07.13 02:38:20.189663 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MACStringToNum: In scope SELECT MACStringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.311499 [ 32979 ] {237449ea-e9f0-4bb8-9dc3-35bd19ebfb29} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MACStringToOUI: In scope SELECT MACStringToOUI([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 87, line 88) (in query: SELECT MACStringToOUI([]);) 2025.07.13 02:38:20.318472 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MACStringToOUI: In scope SELECT MACStringToOUI([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.354336 [ 32979 ] {289fb6d8-eb6d-47b3-a759-9ecdb7714f4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT MAP_FROM_ARRAYS([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS([]);) 2025.07.13 02:38:20.361264 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT MAP_FROM_ARRAYS([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:20.423796 [ 32979 ] {5d5da3f9-a420-4ee8-b0c0-b5c9b80001f9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MD4: In scope SELECT MD4([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 89, line 90) (in query: SELECT MD4([]);) 2025.07.13 02:38:20.439276 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MD4: In scope SELECT MD4([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.478094 [ 32979 ] {34534140-1713-4ce1-916e-bd90092fef72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MD5: In scope SELECT MD5([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 90, line 91) (in query: SELECT MD5([]);) 2025.07.13 02:38:20.525902 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function MD5: In scope SELECT MD5([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.593163 [ 32979 ] {cccf733e-39b0-4c8f-8314-f6ebf3f4ea41} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MILLISECOND([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 91, line 92) (in query: SELECT MILLISECOND([]);) 2025.07.13 02:38:20.601681 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MILLISECOND([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.629099 [ 32979 ] {3d65aabb-6e6f-46cd-8b27-7aaf59b68fe0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MINUTE([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 92, line 93) (in query: SELECT MINUTE([]);) 2025.07.13 02:38:20.645263 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MINUTE([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.674906 [ 32979 ] {a7e65616-5d42-448f-ba3d-436a93d51988} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MONTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 93, line 94) (in query: SELECT MONTH([]);) 2025.07.13 02:38:20.679453 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MONTH([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.800953 [ 32979 ] {5043d297-3126-41ec-9dd5-0423cf511015} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT QUARTER([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 95, line 96) (in query: SELECT QUARTER([]);) 2025.07.13 02:38:20.809197 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT QUARTER([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:20.845893 [ 32979 ] {5855b4fd-f491-491e-aedb-b243284e18fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT REGEXP_EXTRACT([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 96, line 97) (in query: SELECT REGEXP_EXTRACT([]);) 2025.07.13 02:38:20.851530 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT REGEXP_EXTRACT([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:20.884387 [ 32979 ] {2c4121dd-fc27-44f3-b704-1225240afe70} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT REGEXP_MATCHES([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES([]);) 2025.07.13 02:38:20.891497 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT REGEXP_MATCHES([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:20.963529 [ 32979 ] {3619d9a5-2084-41f6-a2cc-5aa0a828c5da} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT REGEXP_REPLACE([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 98, line 99) (in query: SELECT REGEXP_REPLACE([]);) 2025.07.13 02:38:20.970642 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT REGEXP_REPLACE([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:21.123456 [ 32979 ] {dab69b9d-6986-4af9-b735-00664bbb4584} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function RIPEMD160: In scope SELECT RIPEMD160([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 99, line 100) (in query: SELECT RIPEMD160([]);) 2025.07.13 02:38:21.143848 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function RIPEMD160: In scope SELECT RIPEMD160([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.298069 [ 32979 ] {e9ba889d-4ab9-4fec-adf1-c95abb56143f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT SCHEMA([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 100, line 101) (in query: SELECT SCHEMA([]);) 2025.07.13 02:38:21.323540 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT SCHEMA([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:21.370773 [ 32979 ] {40731f7b-8369-4ab3-a7ea-d948fec052ac} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT SECOND([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 101, line 102) (in query: SELECT SECOND([]);) 2025.07.13 02:38:21.379005 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT SECOND([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.412451 [ 32979 ] {e75baea4-d87b-4f3f-90a3-27303ed592b6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA1: In scope SELECT SHA1([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 102, line 103) (in query: SELECT SHA1([]);) 2025.07.13 02:38:21.417298 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA1: In scope SELECT SHA1([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.520534 [ 32979 ] {3f5fad99-3fa1-418b-86e9-e3f14659a94f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA224: In scope SELECT SHA224([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 103, line 104) (in query: SELECT SHA224([]);) 2025.07.13 02:38:21.533766 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA224: In scope SELECT SHA224([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.568265 [ 32979 ] {9f8f1228-6fc8-4502-bc2d-3b6e2b6ca5c7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA256: In scope SELECT SHA256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 104, line 105) (in query: SELECT SHA256([]);) 2025.07.13 02:38:21.575468 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA256: In scope SELECT SHA256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.612123 [ 32979 ] {40b4fba9-3663-47ab-a062-95b81d57bce0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA384: In scope SELECT SHA384([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 105, line 106) (in query: SELECT SHA384([]);) 2025.07.13 02:38:21.635584 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA384: In scope SELECT SHA384([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.699712 [ 32979 ] {66911531-dafa-4e40-b28b-1e855e119e6a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA512: In scope SELECT SHA512([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 106, line 107) (in query: SELECT SHA512([]);) 2025.07.13 02:38:21.708631 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA512: In scope SELECT SHA512([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.748147 [ 32979 ] {7c08ae15-ac9e-4599-be74-fccecc10d622} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA512_256: In scope SELECT SHA512_256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 107, line 108) (in query: SELECT SHA512_256([]);) 2025.07.13 02:38:21.752341 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function SHA512_256: In scope SELECT SHA512_256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.777746 [ 32979 ] {bb4044d4-6d12-47b5-940a-2a1e736e4c62} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 108, line 109) (in query: SELECT STD([]);) 2025.07.13 02:38:21.783415 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.811841 [ 32979 ] {b9b03c66-f4e0-4cde-997f-e37d89a1fef5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 109, line 110) (in query: SELECT STDDEV_POP([]);) 2025.07.13 02:38:21.816277 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.841605 [ 32979 ] {9bd33fb1-2814-4cfe-9331-7ee8389f702d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 110, line 111) (in query: SELECT STDDEV_SAMP([]);) 2025.07.13 02:38:21.846135 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:21.870673 [ 32979 ] {346da5de-ec93-4b8f-9136-cf4c71a85e6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT SUBSTRING_INDEX([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 111, line 112) (in query: SELECT SUBSTRING_INDEX([]);) 2025.07.13 02:38:21.874790 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT SUBSTRING_INDEX([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:21.933142 [ 32979 ] {12efce82-e384-4507-8082-4d376ded48e9} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT SVG([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 112, line 113) (in query: SELECT SVG([]);) 2025.07.13 02:38:21.937764 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT SVG([]). (BAD_ARGUMENTS) 2025.07.13 02:38:21.992689 [ 32979 ] {dd572d0e-a708-4caf-8715-db079413e868} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 113, line 114) (in query: SELECT TIMESTAMP_DIFF([]);) 2025.07.13 02:38:22.005680 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:22.049783 [ 32979 ] {46a28f38-2388-426a-a57c-381f3715d547} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT TO_BASE64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 114, line 115) (in query: SELECT TO_BASE64([]);) 2025.07.13 02:38:22.052987 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT TO_BASE64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.083740 [ 32979 ] {82c88af3-c5f7-4f48-8037-73c22539a01d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT TO_DAYS([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 115, line 116) (in query: SELECT TO_DAYS([]);) 2025.07.13 02:38:22.094695 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT TO_DAYS([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.144542 [ 32979 ] {3768a334-467a-4e80-8d68-32c9e7f05898} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT TO_UNIXTIME([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 116, line 117) (in query: SELECT TO_UNIXTIME([]);) 2025.07.13 02:38:22.156625 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT TO_UNIXTIME([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.203008 [ 32979 ] {c0bcd57f-8ab0-4809-aa41-c97ed1904f60} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 117, line 118) (in query: SELECT ULIDStringToDateTime([]);) 2025.07.13 02:38:22.209100 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.323281 [ 32979 ] {7e82d9d0-0dd3-49fe-8a7b-dff478dcd874} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function URLHash: In scope SELECT URLHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 118, line 119) (in query: SELECT URLHash([]);) 2025.07.13 02:38:22.330223 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function URLHash: In scope SELECT URLHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.379661 [ 32979 ] {9c89a841-54c9-4006-a1dc-cacc77dbcd94} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLHierarchy'. Expected: String, got: Array(Nothing): In scope SELECT URLHierarchy([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 119, line 120) (in query: SELECT URLHierarchy([]);) 2025.07.13 02:38:22.386531 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLHierarchy'. Expected: String, got: Array(Nothing): In scope SELECT URLHierarchy([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.447445 [ 32979 ] {156862da-e228-4f35-815a-0537093ed619} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLPathHierarchy'. Expected: String, got: Array(Nothing): In scope SELECT URLPathHierarchy([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy([]);) 2025.07.13 02:38:22.454946 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLPathHierarchy'. Expected: String, got: Array(Nothing): In scope SELECT URLPathHierarchy([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.507101 [ 32979 ] {2deb2c62-9264-4873-a89f-a13f18c21fd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTCTimestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 121, line 122) (in query: SELECT UTCTimestamp([]);) 2025.07.13 02:38:22.513490 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTCTimestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:22.582247 [ 32979 ] {7455ba1f-94ae-4b7a-9387-914be660c403} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTC_timestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 122, line 123) (in query: SELECT UTC_timestamp([]);) 2025.07.13 02:38:22.596396 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTC_timestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:22.654673 [ 32979 ] {c361a0c7-3d7d-4ea0-acb4-1c7caa0ea66c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function UUIDNumToString, expected FixedString(16): In scope SELECT UUIDNumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 123, line 124) (in query: SELECT UUIDNumToString([]);) 2025.07.13 02:38:22.661158 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function UUIDNumToString, expected FixedString(16): In scope SELECT UUIDNumToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.756494 [ 32979 ] {3ce1f587-cd66-42a5-a1c7-86c4edb55812} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDStringToNum, expected FixedString(36): In scope SELECT UUIDStringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 124, line 125) (in query: SELECT UUIDStringToNum([]);) 2025.07.13 02:38:22.767220 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDStringToNum, expected FixedString(36): In scope SELECT UUIDStringToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.870963 [ 32979 ] {03ffa412-2d9e-46c3-ad21-3c17bffd0402} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDToNum, expected UUID: In scope SELECT UUIDToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 125, line 126) (in query: SELECT UUIDToNum([]);) 2025.07.13 02:38:22.889142 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDToNum, expected UUID: In scope SELECT UUIDToNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:22.991901 [ 32979 ] {9e491bd0-6389-4b1a-9345-c1d01a439d1d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDv7ToDateTime, expected UUID: In scope SELECT UUIDv7ToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 126, line 127) (in query: SELECT UUIDv7ToDateTime([]);) 2025.07.13 02:38:23.010795 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDv7ToDateTime, expected UUID: In scope SELECT UUIDv7ToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.041798 [ 32979 ] {88345719-add0-44f5-94d8-c6d1a1034a1e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 127, line 128) (in query: SELECT VAR_POP([]);) 2025.07.13 02:38:23.048445 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.092904 [ 32979 ] {5a5df60e-e6fd-40b0-8300-dd2fda5343b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 128, line 129) (in query: SELECT VAR_SAMP([]);) 2025.07.13 02:38:23.099685 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.143997 [ 32979 ] {94a45b24-fecc-46d5-bcbc-16ba08f89419} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT YEAR([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 129, line 130) (in query: SELECT YEAR([]);) 2025.07.13 02:38:23.150165 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT YEAR([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.194438 [ 32979 ] {b6f68f1d-3361-4849-83a9-7e9c2152c4a4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDToDate([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 130, line 131) (in query: SELECT YYYYMMDDToDate([]);) 2025.07.13 02:38:23.208391 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDToDate([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.313526 [ 32979 ] {b9b7a63a-d783-4498-a541-aeec68ba0d18} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDToDate32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 131, line 132) (in query: SELECT YYYYMMDDToDate32([]);) 2025.07.13 02:38:23.325027 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDToDate32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.350995 [ 32979 ] {711ef0f8-5bef-4415-8981-0ce71cef8028} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 132, line 133) (in query: SELECT YYYYMMDDhhmmssToDateTime([]);) 2025.07.13 02:38:23.422295 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.458893 [ 32979 ] {ecf43c6c-9d92-42e2-9166-553755d63aa1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 133, line 134) (in query: SELECT YYYYMMDDhhmmssToDateTime64([]);) 2025.07.13 02:38:23.470499 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.473610 [ 34273 ] {991f50f2-009a-414e-8410-b69c3da8e460} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59948) (comment: 00126_buffer.sql) (query 53, line 61) (in query: DROP TABLE buffer_00126;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:38:23.496466 [ 34273 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003031d738 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb3545 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 2025.07.13 02:38:23.533301 [ 32979 ] {00c0fcbe-63ae-407e-b94b-88cdeec37ccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 134, line 135) (in query: SELECT _CAST([]);) 2025.07.13 02:38:23.538422 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:23.607602 [ 32979 ] {052006d3-177a-4a8e-951c-ce2e5c583e2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 1, should be 2: In scope SELECT __actionName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 135, line 136) (in query: SELECT __actionName([]);) 2025.07.13 02:38:23.618996 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 1, should be 2: In scope SELECT __actionName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:23.677879 [ 32979 ] {84850f8d-b50c-4244-a149-7e92edebc243} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskAnd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd([]);) 2025.07.13 02:38:23.682409 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskAnd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:23.720085 [ 32979 ] {2875feba-b7bf-416b-bc79-b3dadebf2e04} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskOr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr([]);) 2025.07.13 02:38:23.731903 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskOr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:23.835934 [ 32979 ] {8dfc8d7d-a80f-4a14-ae8a-8a760f52c560} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function __bitSwapLastTwo: In scope SELECT __bitSwapLastTwo([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo([]);) 2025.07.13 02:38:23.845565 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function __bitSwapLastTwo: In scope SELECT __bitSwapLastTwo([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.897425 [ 32979 ] {3c36cbd8-eafd-488e-a163-4d2fa59ae69e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function __bitWrapperFunc: In scope SELECT __bitWrapperFunc([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc([]);) 2025.07.13 02:38:23.907093 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function __bitWrapperFunc: In scope SELECT __bitWrapperFunc([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:23.980027 [ 32979 ] {9e4cd1bd-9b5e-4802-b0f3-13780b5eabef} executeQuery: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 140, line 141) (in query: SELECT __getScalar([]);) 2025.07.13 02:38:23.985264 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:24.193327 [ 32979 ] {a6a562df-bf52-4a9b-add5-bc2b8be96b72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function abs: In scope SELECT abs([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 142, line 143) (in query: SELECT abs([]);) 2025.07.13 02:38:24.203307 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function abs: In scope SELECT abs([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:24.234026 [ 32979 ] {81663443-368a-4a79-b9e6-ec2f17fcf19e} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 1, should be 2: In scope SELECT accurateCast([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 143, line 144) (in query: SELECT accurateCast([]);) 2025.07.13 02:38:24.247219 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 1, should be 2: In scope SELECT accurateCast([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.329101 [ 32979 ] {0ca9f639-41fc-47d8-9693-946ce24160f1} executeQuery: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 1: In scope SELECT accurateCastOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault([]);) 2025.07.13 02:38:24.355848 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 1: In scope SELECT accurateCastOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.412056 [ 32979 ] {4066afbf-c654-41ee-bea1-f09777cfadbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 1, should be 2: In scope SELECT accurateCastOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull([]);) 2025.07.13 02:38:24.439047 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 1, should be 2: In scope SELECT accurateCastOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.513419 [ 32979 ] {10a1254d-89d5-4efa-b474-24ff9d9b6be3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function acos: In scope SELECT acos([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 146, line 147) (in query: SELECT acos([]);) 2025.07.13 02:38:24.532282 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function acos: In scope SELECT acos([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:24.579144 [ 32979 ] {67efe6a4-71b9-4d61-b0cb-f69636800ff4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function acosh: In scope SELECT acosh([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 147, line 148) (in query: SELECT acosh([]);) 2025.07.13 02:38:24.585419 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function acosh: In scope SELECT acosh([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:24.626938 [ 32979 ] {1ffd0ea3-9112-4998-af54-1c681d31667c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 148, line 149) (in query: SELECT addDate([]);) 2025.07.13 02:38:24.633046 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.683565 [ 32979 ] {65ea24bb-a54b-44ec-961e-edc20bb4e944} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 1, should be 2 or 3: In scope SELECT addDays([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 149, line 150) (in query: SELECT addDays([]);) 2025.07.13 02:38:24.740769 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 1, should be 2 or 3: In scope SELECT addDays([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.807820 [ 32979 ] {6835abb9-383c-4d60-b1ec-2f332cc82539} executeQuery: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 1, should be 2 or 3: In scope SELECT addHours([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 150, line 151) (in query: SELECT addHours([]);) 2025.07.13 02:38:24.814378 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 1, should be 2 or 3: In scope SELECT addHours([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.840239 [ 32979 ] {8d96c435-5a11-4ee3-9cf3-2cfa1b95258e} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 1, should be 2: In scope SELECT addInterval([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 151, line 152) (in query: SELECT addInterval([]);) 2025.07.13 02:38:24.846171 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 1, should be 2: In scope SELECT addInterval([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.891603 [ 32979 ] {83e79279-8bd6-4faf-a679-64d259731832} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMicroseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 152, line 153) (in query: SELECT addMicroseconds([]);) 2025.07.13 02:38:24.896530 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMicroseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.943827 [ 32979 ] {1277d980-662f-4fc3-87cb-165703739e1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMilliseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 153, line 154) (in query: SELECT addMilliseconds([]);) 2025.07.13 02:38:24.956869 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMilliseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:24.990980 [ 32979 ] {ba0e02ca-43a7-4814-a10f-335b1f020afd} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT addMinutes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 154, line 155) (in query: SELECT addMinutes([]);) 2025.07.13 02:38:24.995497 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT addMinutes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.036824 [ 32979 ] {7e7af337-a75e-4d23-b12b-a69e76b024d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT addMonths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 155, line 156) (in query: SELECT addMonths([]);) 2025.07.13 02:38:25.046638 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT addMonths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.092056 [ 32979 ] {0509ecf3-da7e-48b9-9bd8-e96bf01ce4e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addNanoseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 156, line 157) (in query: SELECT addNanoseconds([]);) 2025.07.13 02:38:25.097784 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addNanoseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.158237 [ 32979 ] {cbf5bc0f-2d7e-4544-9e66-5ff54d96653c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT addQuarters([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 157, line 158) (in query: SELECT addQuarters([]);) 2025.07.13 02:38:25.180204 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT addQuarters([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.208419 [ 32979 ] {d4f7b65a-3343-494c-9954-260770c2c78a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addSeconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 158, line 159) (in query: SELECT addSeconds([]);) 2025.07.13 02:38:25.217733 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addSeconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.282298 [ 32979 ] {db9209b2-f710-479c-aebb-d02ee165036a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT addTupleOfIntervals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals([]);) 2025.07.13 02:38:25.285993 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT addTupleOfIntervals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.303470 [ 32979 ] {0959f997-05b3-4112-8915-6ce440c41ec4} executeQuery: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT addWeeks([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 160, line 161) (in query: SELECT addWeeks([]);) 2025.07.13 02:38:25.307611 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT addWeeks([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.342287 [ 32979 ] {015e8443-41a7-4723-8cb4-d0855f229642} executeQuery: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 1, should be 2 or 3: In scope SELECT addYears([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 161, line 162) (in query: SELECT addYears([]);) 2025.07.13 02:38:25.347206 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 1, should be 2 or 3: In scope SELECT addYears([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.390441 [ 32979 ] {be90c0fc-bd72-48ba-b60a-a40d41446419} executeQuery: Code: 43. DB::Exception: The only argument for function addressToLine must be UInt64. Found Array(Nothing) instead.: In scope SELECT addressToLine([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 162, line 163) (in query: SELECT addressToLine([]);) 2025.07.13 02:38:25.396676 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function addressToLine must be UInt64. Found Array(Nothing) instead.: In scope SELECT addressToLine([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:25.409887 [ 7056 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:38:25.460624 [ 32979 ] {6f9a4ba7-d986-4044-aee0-1dc77e507197} executeQuery: Code: 43. DB::Exception: The only argument for function addressToLineWithInlines must be UInt64. Found Array(Nothing) instead.: In scope SELECT addressToLineWithInlines([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines([]);) 2025.07.13 02:38:25.471010 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function addressToLineWithInlines must be UInt64. Found Array(Nothing) instead.: In scope SELECT addressToLineWithInlines([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:25.521899 [ 32979 ] {81b3dada-7925-4725-b357-e6e56a9fe64c} executeQuery: Code: 43. DB::Exception: The only argument for function addressToSymbol must be UInt64. Found Array(Nothing) instead.: In scope SELECT addressToSymbol([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 164, line 165) (in query: SELECT addressToSymbol([]);) 2025.07.13 02:38:25.533037 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function addressToSymbol must be UInt64. Found Array(Nothing) instead.: In scope SELECT addressToSymbol([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:25.554832 [ 32979 ] {cb21220c-df34-4451-8c99-04045cffe230} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 165, line 166) (in query: SELECT aes_decrypt_mysql([]);) 2025.07.13 02:38:25.621676 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.671970 [ 32979 ] {bb42dd88-8fb7-496a-97e2-833806e6b882} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 166, line 167) (in query: SELECT aes_encrypt_mysql([]);) 2025.07.13 02:38:25.682490 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.719229 [ 32979 ] {d9c681f9-c878-45b5-b52c-00335ac5a17b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT age([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 167, line 168) (in query: SELECT age([]);) 2025.07.13 02:38:25.723076 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT age([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.755046 [ 32979 ] {4c9c4e73-0e0e-4da0-92c5-b64322aa3295} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 168, line 169) (in query: SELECT aggThrow([]);) 2025.07.13 02:38:25.759277 [ 32979 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.07.13 02:38:25.783161 [ 32979 ] {ce0e71cc-12ed-4754-809e-509edb3c54be} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT alphaTokens([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 169, line 170) (in query: SELECT alphaTokens([]);) 2025.07.13 02:38:25.786619 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT alphaTokens([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:25.846597 [ 32979 ] {05f6c538-0f70-4fb4-abe7-0184cb74bedc} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 170, line 171) (in query: SELECT analysisOfVariance([]);) 2025.07.13 02:38:25.854906 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:25.929005 [ 32979 ] {2f196a38-c047-4e5b-835b-dd4e987193b9} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT and([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 171, line 172) (in query: SELECT and([]);) 2025.07.13 02:38:25.949460 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT and([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:26.110253 [ 32979 ] {ca163e62-d983-40f3-8a97-60afc0e20eed} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 172, line 173) (in query: SELECT anova([]);) 2025.07.13 02:38:26.114030 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:27.742031 [ 32979 ] {841f315e-57d5-4fce-8319-dc8289091aa2} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 1, should be 2: In scope SELECT appendTrailingCharIfAbsent([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent([]);) 2025.07.13 02:38:27.746657 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 1, should be 2: In scope SELECT appendTrailingCharIfAbsent([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:27.925316 [ 32979 ] {9d6963cc-6132-4a0f-b562-26b2e5f6159d} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 186, line 187) (in query: SELECT approx_top_sum([]);) 2025.07.13 02:38:27.931647 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:27.965007 [ 32979 ] {8eb9ef7c-fbe8-43e8-ba06-51366eb429df} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 187, line 188) (in query: SELECT argMax([]);) 2025.07.13 02:38:27.971824 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:28.075452 [ 32979 ] {6e6739ef-ff47-4097-9d33-b216c3940250} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 188, line 189) (in query: SELECT argMin([]);) 2025.07.13 02:38:28.082624 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:28.244322 [ 32979 ] {2f6c48dc-a538-4314-952b-7593682bb650} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayAUC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 190, line 191) (in query: SELECT arrayAUC([]);) 2025.07.13 02:38:28.252380 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayAUC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:28.294511 [ 32979 ] {98a64e6a-b75a-4acc-b979-b1f94b925fa6} 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([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 191, line 192) (in query: SELECT arrayAUCPR([]);) 2025.07.13 02:38:28.311767 [ 32979 ] {} 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([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:28.450730 [ 32979 ] {091944c8-6f4f-4519-b121-b6da3474cd82} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayAll must be array of UInt8. Found Array(Nothing) instead: In scope SELECT arrayAll([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 192, line 193) (in query: SELECT arrayAll([]);) 2025.07.13 02:38:28.457646 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayAll must be array of UInt8. Found Array(Nothing) instead: In scope SELECT arrayAll([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:28.674517 [ 32979 ] {d44c7117-fb9a-473a-9361-1f3a6b480fce} executeQuery: Code: 43. DB::Exception: array aggregation function cannot be performed on type Nothing: In scope SELECT arrayAvg([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 193, line 194) (in query: SELECT arrayAvg([]);) 2025.07.13 02:38:28.681529 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: array aggregation function cannot be performed on type Nothing: In scope SELECT arrayAvg([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:28.824696 [ 32979 ] {18e138c3-fb6e-4ebd-9708-f8498ddf4fa5} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayCount must be array of UInt8. Found Array(Nothing) instead: In scope SELECT arrayCount([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 196, line 197) (in query: SELECT arrayCount([]);) 2025.07.13 02:38:28.828478 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayCount must be array of UInt8. Found Array(Nothing) instead: In scope SELECT arrayCount([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:28.861620 [ 32979 ] {2a826bec-d48e-4075-be69-f00d6a72e8a0} executeQuery: Code: 43. DB::Exception: arrayCumSum cannot add values of type Nothing: In scope SELECT arrayCumSum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 197, line 198) (in query: SELECT arrayCumSum([]);) 2025.07.13 02:38:28.867808 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: arrayCumSum cannot add values of type Nothing: In scope SELECT arrayCumSum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:28.973927 [ 32979 ] {5b38766c-54da-413f-8bbe-7f83ed88a37f} executeQuery: Code: 43. DB::Exception: arrayCumSumNonNegativeImpl cannot add values of type Nothing: In scope SELECT arrayCumSumNonNegative([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 198, line 199) (in query: SELECT arrayCumSumNonNegative([]);) 2025.07.13 02:38:28.979730 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: arrayCumSumNonNegativeImpl cannot add values of type Nothing: In scope SELECT arrayCumSumNonNegative([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:29.012161 [ 32979 ] {c196fe69-8c2a-467e-81b5-1015f2871256} executeQuery: Code: 43. DB::Exception: arrayDifference cannot process values of type Nothing: In scope SELECT arrayDifference([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 199, line 200) (in query: SELECT arrayDifference([]);) 2025.07.13 02:38:29.017940 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: arrayDifference cannot process values of type Nothing: In scope SELECT arrayDifference([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:29.205820 [ 32979 ] {948e7223-187c-4004-a353-0d063128acd6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 1, should be 2: In scope SELECT arrayDotProduct([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 201, line 202) (in query: SELECT arrayDotProduct([]);) 2025.07.13 02:38:29.212384 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 1, should be 2: In scope SELECT arrayDotProduct([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:29.244851 [ 32979 ] {b63172b9-0c95-42b6-aacb-d39ea9e8eb76} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 1, should be 2: In scope SELECT arrayElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 202, line 203) (in query: SELECT arrayElement([]);) 2025.07.13 02:38:29.254382 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 1, should be 2: In scope SELECT arrayElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:29.282390 [ 32979 ] {206e6fd2-3c70-4da3-b455-006df7aa1335} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 1, should be 2: In scope SELECT arrayElementOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull([]);) 2025.07.13 02:38:29.286684 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 1, should be 2: In scope SELECT arrayElementOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.087633 [ 32979 ] {a9958150-d597-41db-a400-bdf6dc568abf} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayExists must be array of UInt8. Found Array(Nothing) instead: In scope SELECT arrayExists([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 209, line 210) (in query: SELECT arrayExists([]);) 2025.07.13 02:38:30.097608 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayExists must be array of UInt8. Found Array(Nothing) instead: In scope SELECT arrayExists([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:30.161981 [ 32979 ] {6ccdd45d-12fe-4974-8221-fee49e5162ca} executeQuery: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 1: In scope SELECT arrayFill([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 210, line 211) (in query: SELECT arrayFill([]);) 2025.07.13 02:38:30.169135 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 1: In scope SELECT arrayFill([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.266867 [ 32979 ] {4fd78d4a-9a9c-43bc-a8fc-5ff845a10704} executeQuery: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 1: In scope SELECT arrayFilter([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 211, line 212) (in query: SELECT arrayFilter([]);) 2025.07.13 02:38:30.272183 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 1: In scope SELECT arrayFilter([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.322093 [ 32979 ] {dba67abc-46a6-4da5-abce-2246fa150801} executeQuery: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 1: In scope SELECT arrayFirst([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 212, line 213) (in query: SELECT arrayFirst([]);) 2025.07.13 02:38:30.330817 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 1: In scope SELECT arrayFirst([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.368442 [ 32979 ] {e3ee8567-e5f1-4c73-895c-936b575e976a} executeQuery: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 1: In scope SELECT arrayFirstIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 213, line 214) (in query: SELECT arrayFirstIndex([]);) 2025.07.13 02:38:30.373683 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 1: In scope SELECT arrayFirstIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.412860 [ 32979 ] {497105dc-cd5b-4b85-afc0-9a0d56585e3a} executeQuery: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayFirstOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 214, line 215) (in query: SELECT arrayFirstOrNull([]);) 2025.07.13 02:38:30.420249 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayFirstOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.545147 [ 32979 ] {94476165-b0dc-41f5-a9a2-8a2a1ac9c07c} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 216, line 217) (in query: SELECT arrayFold([]);) 2025.07.13 02:38:30.549552 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:30.695378 [ 32979 ] {7dd80fed-735b-49c0-b5f2-b86fde3bf1ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT arrayJaccardIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex([]);) 2025.07.13 02:38:30.701107 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT arrayJaccardIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.793530 [ 32979 ] {81e19c26-a644-4d5a-9b23-c741bcfd92bc} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 219, line 220) (in query: SELECT arrayJoin([]);) 2025.07.13 02:38:30.799122 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:30.822552 [ 32979 ] {d29a104a-8eb2-4306-8efa-f62c33bd03ce} executeQuery: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 1: In scope SELECT arrayLast([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 220, line 221) (in query: SELECT arrayLast([]);) 2025.07.13 02:38:30.827628 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 1: In scope SELECT arrayLast([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.855687 [ 32979 ] {80e4f925-5444-41f2-ba15-994008d89f5a} executeQuery: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 1: In scope SELECT arrayLastIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 221, line 222) (in query: SELECT arrayLastIndex([]);) 2025.07.13 02:38:30.862112 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 1: In scope SELECT arrayLastIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.900231 [ 32979 ] {9607e9a8-babe-406c-980c-93ad6f164191} executeQuery: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayLastOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 222, line 223) (in query: SELECT arrayLastOrNull([]);) 2025.07.13 02:38:30.907630 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayLastOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:30.956538 [ 32979 ] {4c74282e-7409-4b5c-820d-96fb9e578ace} executeQuery: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 1: In scope SELECT arrayMap([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 223, line 224) (in query: SELECT arrayMap([]);) 2025.07.13 02:38:30.965505 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 1: In scope SELECT arrayMap([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:31.112079 [ 32979 ] {5f797fee-67aa-466c-bab1-339ad4f889bd} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayMax([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 224, line 225) (in query: SELECT arrayMax([]);) 2025.07.13 02:38:31.123385 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayMax([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:31.182044 [ 32979 ] {0ca0edf5-9941-4fd3-974f-572627a6b6e7} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayMin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 225, line 226) (in query: SELECT arrayMin([]);) 2025.07.13 02:38:31.192849 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayMin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:31.345657 [ 32979 ] {ec60f69c-0693-4946-8269-48f5e436b550} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 1, should be 2: In scope SELECT arrayNormalizedGini([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini([]);) 2025.07.13 02:38:31.352809 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 1, should be 2: In scope SELECT arrayNormalizedGini([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:31.412304 [ 32979 ] {45d3e590-03e2-4335-9614-1c18c8318f0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayPRAUC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 227, line 228) (in query: SELECT arrayPRAUC([]);) 2025.07.13 02:38:31.416654 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayPRAUC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:31.454233 [ 32979 ] {c08e895f-266a-4585-b011-b594043e8b6c} executeQuery: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialReverseSort([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 228, line 229) (in query: SELECT arrayPartialReverseSort([]);) 2025.07.13 02:38:31.461988 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialReverseSort([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:31.654246 [ 32979 ] {764e15fc-5ba8-41cb-8878-85041b238093} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 230, line 231) (in query: SELECT arrayPartialSort([]);) 2025.07.13 02:38:31.659349 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:31.903382 [ 32979 ] {c92abfe0-c088-46a2-bfd9-8b054b18d8c3} executeQuery: Code: 43. DB::Exception: array aggregation function cannot be performed on type Nothing: In scope SELECT arrayProduct([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 233, line 234) (in query: SELECT arrayProduct([]);) 2025.07.13 02:38:31.908290 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: array aggregation function cannot be performed on type Nothing: In scope SELECT arrayProduct([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:31.956074 [ 32979 ] {e607ee84-25fb-4d23-9c14-73d0d18550e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 1, should be 2: In scope SELECT arrayPushBack([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 234, line 235) (in query: SELECT arrayPushBack([]);) 2025.07.13 02:38:31.961397 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 1, should be 2: In scope SELECT arrayPushBack([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.006315 [ 32979 ] {345efbac-0e74-482f-ab67-37dcf183957d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 1, should be 2: In scope SELECT arrayPushFront([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 235, line 236) (in query: SELECT arrayPushFront([]);) 2025.07.13 02:38:32.014282 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 1, should be 2: In scope SELECT arrayPushFront([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.050622 [ 32979 ] {202a4564-32e1-4217-8bb1-7dce064a60b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayROCAUC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 236, line 237) (in query: SELECT arrayROCAUC([]);) 2025.07.13 02:38:32.053886 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayROCAUC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.090075 [ 32979 ] {11266422-7e68-45c0-923e-96c7cc2f9585} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 1, should be 2: In scope SELECT arrayRandomSample([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 237, line 238) (in query: SELECT arrayRandomSample([]);) 2025.07.13 02:38:32.096106 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 1, should be 2: In scope SELECT arrayRandomSample([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.103099 [ 5380 ] {0303ac62-09b5-47a1-a273-0f7f26dab7ec} executeQuery: Code: 60. DB::Exception: Table test_3ka5zlz3.test_replicated does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40714) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 2) (in query: DROP TABLE test_replicated;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:38:32.112207 [ 5380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3ka5zlz3.test_replicated does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:38:32.135042 [ 32979 ] {7f9b122f-69ac-4b1c-ba1f-4e0485fe3dfe} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 1, should be at least 2.: In scope SELECT arrayReduce([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 238, line 239) (in query: SELECT arrayReduce([]);) 2025.07.13 02:38:32.142773 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 1, should be at least 2.: In scope SELECT arrayReduce([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:32.182035 [ 32979 ] {ea5c54ec-8b5a-4daa-be9d-c4d11db1a8ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 1, should be at least 3.: In scope SELECT arrayReduceInRanges([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 239, line 240) (in query: SELECT arrayReduceInRanges([]);) 2025.07.13 02:38:32.186288 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 1, should be at least 3.: In scope SELECT arrayReduceInRanges([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.262154 [ 32979 ] {27a50288-535d-4950-8e33-eac33d94846e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayResize'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT arrayResize([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 240, line 241) (in query: SELECT arrayResize([]);) 2025.07.13 02:38:32.268242 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayResize'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT arrayResize([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.389898 [ 32979 ] {35d03f67-a851-48dd-b844-c79136068752} executeQuery: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 1: In scope SELECT arrayReverseFill([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 242, line 243) (in query: SELECT arrayReverseFill([]);) 2025.07.13 02:38:32.395752 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 1: In scope SELECT arrayReverseFill([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.504072 [ 32979 ] {c6b4b11d-267b-4689-afd2-67d1642d65ab} executeQuery: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 1: In scope SELECT arrayReverseSplit([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 244, line 245) (in query: SELECT arrayReverseSplit([]);) 2025.07.13 02:38:32.513339 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 1: In scope SELECT arrayReverseSplit([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.552343 [ 32979 ] {1c7b5ca5-74d2-4142-a45e-1dfa4100ff40} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 1, should be 2: In scope SELECT arrayRotateLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft([]);) 2025.07.13 02:38:32.558416 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 1, should be 2: In scope SELECT arrayRotateLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.699033 [ 32979 ] {527e8643-751f-49a8-acba-2cd47072e73e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 1, should be 2: In scope SELECT arrayRotateRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 246, line 247) (in query: SELECT arrayRotateRight([]);) 2025.07.13 02:38:32.704904 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 1, should be 2: In scope SELECT arrayRotateRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.751210 [ 32979 ] {e9d29b45-cf40-4c6b-b6a0-b15f2dc347d6} executeQuery: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 247, line 248) (in query: SELECT arrayShiftLeft([]);) 2025.07.13 02:38:32.759943 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.814036 [ 32979 ] {106bac44-ba94-4d00-bc56-205d60e8a3c2} executeQuery: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 248, line 249) (in query: SELECT arrayShiftRight([]);) 2025.07.13 02:38:32.834446 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:32.922448 [ 32979 ] {7f1c463f-b441-48bb-98bb-023f276d9813} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 249, line 250) (in query: SELECT arrayShingles([]);) 2025.07.13 02:38:32.928529 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:33.017990 [ 32979 ] {4a27a285-6a24-42d0-826a-5e60dd3b8472} executeQuery: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 1, should be 2 or 3: In scope SELECT arraySlice([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 251, line 252) (in query: SELECT arraySlice([]);) 2025.07.13 02:38:33.021023 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 1, should be 2 or 3: In scope SELECT arraySlice([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:33.093702 [ 32979 ] {278386b9-5f9a-48a0-b84e-0fd936c48eac} executeQuery: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 1: In scope SELECT arraySplit([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 253, line 254) (in query: SELECT arraySplit([]);) 2025.07.13 02:38:33.102765 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 1: In scope SELECT arraySplit([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:33.233858 [ 32979 ] {26339539-f87e-4333-969c-ad0ce888fac6} executeQuery: Code: 43. DB::Exception: array aggregation function cannot be performed on type Nothing: In scope SELECT arraySum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 255, line 256) (in query: SELECT arraySum([]);) 2025.07.13 02:38:33.246136 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: array aggregation function cannot be performed on type Nothing: In scope SELECT arraySum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:33.711492 [ 3449 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9c26bd11-e33e-4caf-9c46-d10192a9d6d0::202507_1_166_33}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:38:33.746685 [ 32979 ] {86c13dfe-4c55-4122-b6c3-c003158e88a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 1, should be 2: In scope SELECT arrayWithConstant([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 259, line 260) (in query: SELECT arrayWithConstant([]);) 2025.07.13 02:38:33.749719 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 1, should be 2: In scope SELECT arrayWithConstant([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:34.133131 [ 32979 ] {a9485e33-d2d6-4bd3-896c-278410f69d48} executeQuery: Code: 43. DB::Exception: Cannot apply function ascii to Array argument: In scope SELECT ascii([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 264, line 265) (in query: SELECT ascii([]);) 2025.07.13 02:38:34.136780 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function ascii to Array argument: In scope SELECT ascii([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.159066 [ 32979 ] {bf1a6638-2d53-4072-9b4d-0d33b4452244} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function asin: In scope SELECT asin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 265, line 266) (in query: SELECT asin([]);) 2025.07.13 02:38:34.223740 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function asin: In scope SELECT asin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.253761 [ 32979 ] {341f6003-f45a-42c2-a02c-671e5558d6be} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function asinh: In scope SELECT asinh([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 266, line 267) (in query: SELECT asinh([]);) 2025.07.13 02:38:34.260545 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function asinh: In scope SELECT asinh([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.349984 [ 32979 ] {99f4f809-aefc-4e6d-8a60-847bd14962c6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function atan: In scope SELECT atan([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 268, line 269) (in query: SELECT atan([]);) 2025.07.13 02:38:34.353808 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function atan: In scope SELECT atan([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.376076 [ 32979 ] {9d3caf51-c360-4acf-ac6f-3b7c31ea6e75} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 1, should be 2: In scope SELECT atan2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 269, line 270) (in query: SELECT atan2([]);) 2025.07.13 02:38:34.379314 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 1, should be 2: In scope SELECT atan2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:34.394679 [ 32979 ] {eb375d66-f5c6-4bed-a686-a27932bbf3b8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function atanh: In scope SELECT atanh([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 270, line 271) (in query: SELECT atanh([]);) 2025.07.13 02:38:34.453072 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function atanh: In scope SELECT atanh([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.489086 [ 32979 ] {3f6ed2b4-797a-4484-82b2-75cb0bdf1648} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function avg. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 271, line 272) (in query: SELECT avg([]);) 2025.07.13 02:38:34.494782 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function avg. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.527677 [ 32979 ] {f3eecd30-ca6f-4418-80d8-adbe56a3246d} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 272, line 273) (in query: SELECT avgWeighted([]);) 2025.07.13 02:38:34.533732 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:34.564118 [ 32979 ] {65682654-032e-4f77-be32-34c540a8a638} executeQuery: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 1.: In scope SELECT bar([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 273, line 274) (in query: SELECT bar([]);) 2025.07.13 02:38:34.570246 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 1.: In scope SELECT bar([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:34.604916 [ 32979 ] {8afa571f-38e3-4df7-8718-cc078d999af1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base58Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 274, line 275) (in query: SELECT base58Decode([]);) 2025.07.13 02:38:34.611663 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base58Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.660093 [ 32979 ] {8840ee11-9b72-455d-8475-8cb379112098} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Encode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base58Encode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 275, line 276) (in query: SELECT base58Encode([]);) 2025.07.13 02:38:34.666580 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Encode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base58Encode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.696879 [ 32979 ] {37de6eba-719b-4c63-8e75-6d7562f3be87} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 276, line 277) (in query: SELECT base64Decode([]);) 2025.07.13 02:38:34.704873 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.742443 [ 32979 ] {28990b95-e121-4f82-bd11-4d60c2ba84ec} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64Encode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 277, line 278) (in query: SELECT base64Encode([]);) 2025.07.13 02:38:34.750761 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64Encode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.776884 [ 32979 ] {85f903c4-aa4f-4c76-8a08-44c549fdcd16} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLDecode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64URLDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 278, line 279) (in query: SELECT base64URLDecode([]);) 2025.07.13 02:38:34.781349 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLDecode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64URLDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.892903 [ 32979 ] {74494586-0100-4b1b-bebb-f167f71a9dc2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLEncode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64URLEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 279, line 280) (in query: SELECT base64URLEncode([]);) 2025.07.13 02:38:34.906352 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLEncode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT base64URLEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:34.928801 [ 32979 ] {4afc3f40-7ef1-4a98-b3ca-b3a82cf8d534} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function basename: In scope SELECT basename([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 280, line 281) (in query: SELECT basename([]);) 2025.07.13 02:38:35.013149 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function basename: In scope SELECT basename([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:35.069507 [ 32979 ] {5a427dfa-4661-4ac9-a8ab-aabecd3d8ece} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bin: In scope SELECT bin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 281, line 282) (in query: SELECT bin([]);) 2025.07.13 02:38:35.075618 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bin: In scope SELECT bin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:35.112791 [ 32979 ] {51aaa15d-1b18-4a23-80f7-2d3eea134fe9} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 1, should be 2: In scope SELECT bitAnd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 282, line 283) (in query: SELECT bitAnd([]);) 2025.07.13 02:38:35.130779 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 1, should be 2: In scope SELECT bitAnd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.276129 [ 32979 ] {e1d9949c-9af0-4e1e-a821-a427f8c77f10} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bitCount: In scope SELECT bitCount([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 283, line 284) (in query: SELECT bitCount([]);) 2025.07.13 02:38:35.281172 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bitCount: In scope SELECT bitCount([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:35.321902 [ 32979 ] {37ba6467-b68e-4d93-abc8-07c66113544e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 1, should be 2: In scope SELECT bitHammingDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 284, line 285) (in query: SELECT bitHammingDistance([]);) 2025.07.13 02:38:35.336424 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 1, should be 2: In scope SELECT bitHammingDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.374799 [ 32979 ] {b7292c01-c0d7-485e-af74-2b2aab5a41fb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bitNot: In scope SELECT bitNot([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 285, line 286) (in query: SELECT bitNot([]);) 2025.07.13 02:38:35.379484 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bitNot: In scope SELECT bitNot([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:35.402324 [ 32979 ] {670560ee-1048-4819-ae21-d72f69c8b780} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 1, should be 2: In scope SELECT bitOr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 286, line 287) (in query: SELECT bitOr([]);) 2025.07.13 02:38:35.407195 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 1, should be 2: In scope SELECT bitOr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.435402 [ 32979 ] {ab04c09e-5c68-4b15-a66b-b8637d04889a} executeQuery: Code: 43. DB::Exception: Illegal type bitPositionsToArray of argument of function Array(Nothing): In scope SELECT bitPositionsToArray([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 287, line 288) (in query: SELECT bitPositionsToArray([]);) 2025.07.13 02:38:35.438627 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type bitPositionsToArray of argument of function Array(Nothing): In scope SELECT bitPositionsToArray([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:35.458380 [ 32979 ] {33c62982-3763-4712-aadf-210ae9332922} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 1, should be 2: In scope SELECT bitRotateLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 288, line 289) (in query: SELECT bitRotateLeft([]);) 2025.07.13 02:38:35.461431 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 1, should be 2: In scope SELECT bitRotateLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.483424 [ 32979 ] {7c2e2185-2a0a-4693-9db1-bb91687d4870} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 1, should be 2: In scope SELECT bitRotateRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 289, line 290) (in query: SELECT bitRotateRight([]);) 2025.07.13 02:38:35.486940 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 1, should be 2: In scope SELECT bitRotateRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.506530 [ 32979 ] {0e84b413-4337-400c-9c80-bd7dbeb98d43} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 1, should be 2: In scope SELECT bitShiftLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 290, line 291) (in query: SELECT bitShiftLeft([]);) 2025.07.13 02:38:35.509717 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 1, should be 2: In scope SELECT bitShiftLeft([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.542972 [ 32979 ] {615d8361-0edb-44c9-9c8c-887570aeb80e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 1, should be 2: In scope SELECT bitShiftRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 291, line 292) (in query: SELECT bitShiftRight([]);) 2025.07.13 02:38:35.552763 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 1, should be 2: In scope SELECT bitShiftRight([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.569653 [ 32979 ] {37a37067-85dc-411c-a13b-13df2fdc31d8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT bitSlice([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 292, line 293) (in query: SELECT bitSlice([]);) 2025.07.13 02:38:35.572801 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT bitSlice([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.589816 [ 32979 ] {d25a6e93-e15e-4f90-b151-3d8e29576a78} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 1, should be 2: In scope SELECT bitTest([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 293, line 294) (in query: SELECT bitTest([]);) 2025.07.13 02:38:35.593219 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 1, should be 2: In scope SELECT bitTest([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.624750 [ 32979 ] {3dcee8e9-7ea3-4784-bbd3-4970a079dfea} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAll([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 294, line 295) (in query: SELECT bitTestAll([]);) 2025.07.13 02:38:35.630720 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAll([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:35.652540 [ 32979 ] {a0f41357-59d1-4e65-bb07-092fd0e9a15c} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAny([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 295, line 296) (in query: SELECT bitTestAny([]);) 2025.07.13 02:38:35.659204 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAny([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:35.734374 [ 32979 ] {131d6f19-7641-434c-bd68-07ea2ac25816} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 1, should be 2: In scope SELECT bitXor([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 296, line 297) (in query: SELECT bitXor([]);) 2025.07.13 02:38:35.738169 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 1, should be 2: In scope SELECT bitXor([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.762061 [ 32979 ] {50fe44f6-ed38-4f13-9c02-4379aee879ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 1, should be 2: In scope SELECT bitmapAnd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 297, line 298) (in query: SELECT bitmapAnd([]);) 2025.07.13 02:38:35.766485 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 1, should be 2: In scope SELECT bitmapAnd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.798636 [ 32979 ] {7bea9b5a-b02f-4ee8-abdd-eb7ab44c427f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 298, line 299) (in query: SELECT bitmapAndCardinality([]);) 2025.07.13 02:38:35.803098 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.927722 [ 32979 ] {8b4c5061-4ef0-45df-b6b3-efa9b720f780} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 299, line 300) (in query: SELECT bitmapAndnot([]);) 2025.07.13 02:38:35.934208 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.951532 [ 32979 ] {c7affbe3-2783-4684-be07-91c9fe651dc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnotCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 300, line 301) (in query: SELECT bitmapAndnotCardinality([]);) 2025.07.13 02:38:35.954174 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnotCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:35.971567 [ 32979 ] {520181dd-5724-4f1a-bac3-d84cc25e761e} executeQuery: Code: 43. DB::Exception: Unexpected type Array(Nothing) of argument of function bitmapBuild: In scope SELECT bitmapBuild([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 301, line 302) (in query: SELECT bitmapBuild([]);) 2025.07.13 02:38:36.039850 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Unexpected type Array(Nothing) of argument of function bitmapBuild: In scope SELECT bitmapBuild([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.066508 [ 32979 ] {bcbdfb96-6ded-45ad-81e2-521016fc93e7} executeQuery: Code: 43. DB::Exception: First argument for function bitmapCardinality must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapCardinality([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 302, line 303) (in query: SELECT bitmapCardinality([]);) 2025.07.13 02:38:36.069937 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapCardinality must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapCardinality([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.085173 [ 32979 ] {09502d90-b106-4127-8a45-db104ee18dac} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 1, should be 2: In scope SELECT bitmapContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 303, line 304) (in query: SELECT bitmapContains([]);) 2025.07.13 02:38:36.101032 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 1, should be 2: In scope SELECT bitmapContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.132228 [ 32979 ] {0450a7d2-7877-49ca-b36f-1a8d1bf2d6d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 304, line 305) (in query: SELECT bitmapHasAll([]);) 2025.07.13 02:38:36.138252 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.179368 [ 32979 ] {b3f12f1e-8b2b-4958-b78f-10098e9a2be4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 305, line 306) (in query: SELECT bitmapHasAny([]);) 2025.07.13 02:38:36.196546 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.239193 [ 32979 ] {22b9e2f8-f48d-4dd9-8b21-0de9d3837435} executeQuery: Code: 43. DB::Exception: First argument for function bitmapMax must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapMax([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 306, line 307) (in query: SELECT bitmapMax([]);) 2025.07.13 02:38:36.246538 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapMax must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapMax([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.283679 [ 32979 ] {02da522e-71f8-40cf-bb7f-3ba5e71bbdd0} executeQuery: Code: 43. DB::Exception: First argument for function bitmapMin must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapMin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 307, line 308) (in query: SELECT bitmapMin([]);) 2025.07.13 02:38:36.288849 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapMin must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapMin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.311237 [ 32979 ] {d973b1a3-8dc7-4f8b-9c0a-2515b859a27c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 1, should be 2: In scope SELECT bitmapOr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 308, line 309) (in query: SELECT bitmapOr([]);) 2025.07.13 02:38:36.322035 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 1, should be 2: In scope SELECT bitmapOr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.353082 [ 32979 ] {338afa85-10dc-4e3d-9c6a-bc116b617d8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapOrCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 309, line 310) (in query: SELECT bitmapOrCardinality([]);) 2025.07.13 02:38:36.367512 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapOrCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.417922 [ 32979 ] {28c01607-5c89-4f21-8d80-25df98767ead} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetInRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 310, line 311) (in query: SELECT bitmapSubsetInRange([]);) 2025.07.13 02:38:36.421405 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetInRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.446524 [ 32979 ] {5ebe46d6-25e5-4892-8eed-e3efd3b759ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetLimit([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 311, line 312) (in query: SELECT bitmapSubsetLimit([]);) 2025.07.13 02:38:36.458400 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetLimit([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.568674 [ 32979 ] {3e23d13c-8fcc-45af-bcc6-2890fe44416b} executeQuery: Code: 43. DB::Exception: First argument for function bitmapToArray must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapToArray([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 312, line 313) (in query: SELECT bitmapToArray([]);) 2025.07.13 02:38:36.572260 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapToArray must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapToArray([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.605063 [ 32979 ] {4b8b602a-fd84-4d7a-b076-f29ab1d05d91} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 1, should be 3: In scope SELECT bitmapTransform([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 313, line 314) (in query: SELECT bitmapTransform([]);) 2025.07.13 02:38:36.617952 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 1, should be 3: In scope SELECT bitmapTransform([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.647360 [ 32979 ] {864d8513-e05a-45bb-a797-a8b5a2d0517f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 1, should be 2: In scope SELECT bitmapXor([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 314, line 315) (in query: SELECT bitmapXor([]);) 2025.07.13 02:38:36.651676 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 1, should be 2: In scope SELECT bitmapXor([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.679702 [ 32979 ] {1ad2e565-dc07-49a8-9e04-79082f253f8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapXorCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 315, line 316) (in query: SELECT bitmapXorCardinality([]);) 2025.07.13 02:38:36.685638 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapXorCardinality([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.733644 [ 32979 ] {4383fa47-1244-4a0c-96aa-af61d522f2e7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bitmaskToArray: In scope SELECT bitmaskToArray([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 316, line 317) (in query: SELECT bitmaskToArray([]);) 2025.07.13 02:38:36.736960 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function bitmaskToArray: In scope SELECT bitmaskToArray([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.754674 [ 32979 ] {a130a20f-3cc8-4212-89ef-845ece399f31} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) as bitmask string: In scope SELECT bitmaskToList([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 317, line 318) (in query: SELECT bitmaskToList([]);) 2025.07.13 02:38:36.759620 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) as bitmask string: In scope SELECT bitmaskToList([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:36.788460 [ 32979 ] {529b363f-69fa-437a-9901-d1a28c0f3d6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 1, should be 0: In scope SELECT blockNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 318, line 319) (in query: SELECT blockNumber([]);) 2025.07.13 02:38:36.791775 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 1, should be 0: In scope SELECT blockNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.936726 [ 32979 ] {cfc71fd9-f955-4dcc-b03a-315b9479b7b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 1, should be 0: In scope SELECT blockSize([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 320, line 321) (in query: SELECT blockSize([]);) 2025.07.13 02:38:36.944187 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 1, should be 0: In scope SELECT blockSize([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:36.995093 [ 32979 ] {0447b9d2-f8af-4022-84b8-f354852b76a7} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 321, line 322) (in query: SELECT boundingRatio([]);) 2025.07.13 02:38:37.002385 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.038496 [ 32979 ] {c3390db0-ecd0-4bf2-bf24-c695455addc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 1, should be 0: In scope SELECT buildId([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 322, line 323) (in query: SELECT buildId([]);) 2025.07.13 02:38:37.043521 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 1, should be 0: In scope SELECT buildId([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.068747 [ 32979 ] {8c82862b-a92d-423c-a09e-598e87f381aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT byteHammingDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 323, line 324) (in query: SELECT byteHammingDistance([]);) 2025.07.13 02:38:37.072964 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT byteHammingDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.241589 [ 32979 ] {3b16785b-e154-4b2c-bd62-5e54b318a394} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT byteSlice([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 325, line 326) (in query: SELECT byteSlice([]);) 2025.07.13 02:38:37.247789 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT byteSlice([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.278128 [ 32979 ] {25a540f7-90ac-4e4d-a92d-9c6c0bb3172b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function byteSwap: In scope SELECT byteSwap([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 326, line 327) (in query: SELECT byteSwap([]);) 2025.07.13 02:38:37.291147 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function byteSwap: In scope SELECT byteSwap([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:37.325369 [ 32979 ] {c41b88f8-280a-4c4e-a2bf-f4362955d68d} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpr([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 327, line 328) (in query: SELECT caseWithExpr([]);) 2025.07.13 02:38:37.333456 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpr([]). (BAD_ARGUMENTS) 2025.07.13 02:38:37.375562 [ 32979 ] {81969f03-ad96-416f-961e-cdc56284fedb} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpression([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 328, line 329) (in query: SELECT caseWithExpression([]);) 2025.07.13 02:38:37.381375 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpression([]). (BAD_ARGUMENTS) 2025.07.13 02:38:37.409194 [ 32979 ] {5d8bbcb4-c359-4b43-94b4-fa8275d1482f} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 329, line 330) (in query: SELECT caseWithoutExpr([]);) 2025.07.13 02:38:37.412851 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.439738 [ 32979 ] {49715170-0797-4b15-9e06-0299a057ac6a} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 330, line 331) (in query: SELECT caseWithoutExpression([]);) 2025.07.13 02:38:37.444917 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.474527 [ 32979 ] {7be035f1-2ff1-4e01-8ba5-da5eb2341e41} executeQuery: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 331, line 332) (in query: SELECT catboostEvaluate([]);) 2025.07.13 02:38:37.478665 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:37.566690 [ 32979 ] {66c8b97e-afd9-4ab0-a52d-817e09973eb3} executeQuery: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 332, line 333) (in query: SELECT categoricalInformationValue([]);) 2025.07.13 02:38:37.573742 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.623456 [ 32979 ] {18b852bc-452f-40f1-a319-8f9e5ab5ff5d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cbrt: In scope SELECT cbrt([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 333, line 334) (in query: SELECT cbrt([]);) 2025.07.13 02:38:37.630733 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cbrt: In scope SELECT cbrt([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:37.670755 [ 32979 ] {609163a6-aad5-4c92-9d16-c02fd0de983f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceil([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 334, line 335) (in query: SELECT ceil([]);) 2025.07.13 02:38:37.676793 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceil([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:37.707045 [ 32979 ] {e5b5f082-9ead-42bc-9989-cba2f22d65d6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceiling([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 335, line 336) (in query: SELECT ceiling([]);) 2025.07.13 02:38:37.715327 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceiling([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:37.758722 [ 32979 ] {0336039a-ff71-456d-b1e3-c5c034815dd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 1, should be 2: In scope SELECT changeDay([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 336, line 337) (in query: SELECT changeDay([]);) 2025.07.13 02:38:37.765349 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 1, should be 2: In scope SELECT changeDay([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.799903 [ 32979 ] {05590ba3-deb5-4ab6-b948-e5ae54c98e7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 1, should be 2: In scope SELECT changeHour([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 337, line 338) (in query: SELECT changeHour([]);) 2025.07.13 02:38:37.806957 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 1, should be 2: In scope SELECT changeHour([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.829939 [ 32979 ] {e9e84d0e-edd1-4612-9829-11892f7776de} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 1, should be 2: In scope SELECT changeMinute([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 338, line 339) (in query: SELECT changeMinute([]);) 2025.07.13 02:38:37.832991 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 1, should be 2: In scope SELECT changeMinute([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:37.952510 [ 32979 ] {d33ef769-c320-43a2-9d74-ced42279123d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 1, should be 2: In scope SELECT changeMonth([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 339, line 340) (in query: SELECT changeMonth([]);) 2025.07.13 02:38:37.967125 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 1, should be 2: In scope SELECT changeMonth([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.016704 [ 32979 ] {21fa465c-9052-4f10-85c8-264f80a89d57} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 1, should be 2: In scope SELECT changeSecond([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 340, line 341) (in query: SELECT changeSecond([]);) 2025.07.13 02:38:38.026679 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 1, should be 2: In scope SELECT changeSecond([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.058620 [ 32979 ] {03cca3e6-0419-40e7-aacf-4a91a6c2671b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 341, line 342) (in query: SELECT changeYear([]);) 2025.07.13 02:38:38.062606 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.088783 [ 32979 ] {5ed3e0bf-6fd8-4f2a-a152-332002202388} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 342, line 343) (in query: SELECT char([]);) 2025.07.13 02:38:38.098710 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:38.226408 [ 32979 ] {02502076-324e-46b5-b77f-d12a66c1cc39} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 1, should be 3: In scope SELECT clamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 344, line 345) (in query: SELECT clamp([]);) 2025.07.13 02:38:38.231734 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 1, should be 3: In scope SELECT clamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.306927 [ 32979 ] {4f7752a8-f72c-441d-82a9-e0b3167593ce} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 1 argument: In scope SELECT compareSubstrings([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 346, line 347) (in query: SELECT compareSubstrings([]);) 2025.07.13 02:38:38.310026 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 1 argument: In scope SELECT compareSubstrings([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.371305 [ 32979 ] {79b431b1-fa21-421a-bbf5-cb79262d6e29} executeQuery: Code: 35. DB::Exception: Number of arguments for function concatAssumeInjective should not be 1: In scope SELECT concatAssumeInjective([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 348, line 349) (in query: SELECT concatAssumeInjective([]);) 2025.07.13 02:38:38.374799 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function concatAssumeInjective should not be 1: In scope SELECT concatAssumeInjective([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:38:38.392159 [ 32979 ] {0558e890-1b8d-400b-9ef0-40a8c0db325b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 349, line 350) (in query: SELECT concatWithSeparator([]);) 2025.07.13 02:38:38.395876 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:38.482122 [ 32979 ] {b7d96880-fdab-403f-891c-8a9cb15005f4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 350, line 351) (in query: SELECT concatWithSeparatorAssumeInjective([]);) 2025.07.13 02:38:38.485702 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:38.525636 [ 32979 ] {aee24062-05a1-4614-b1e1-3b84ac536870} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concat_ws([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 351, line 352) (in query: SELECT concat_ws([]);) 2025.07.13 02:38:38.533892 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concat_ws([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:38.562707 [ 32979 ] {5c39343a-0969-4f6c-bb5f-abe132e04246} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connectionId([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 352, line 353) (in query: SELECT connectionId([]);) 2025.07.13 02:38:38.565857 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connectionId([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.788505 [ 32979 ] {2fabe966-4dda-4ac5-8a60-435e2d7cc414} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connection_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 353, line 354) (in query: SELECT connection_id([]);) 2025.07.13 02:38:38.817096 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connection_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.849817 [ 32979 ] {db9b327a-b12c-424e-aaf0-ce7d572ed758} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 354, line 355) (in query: SELECT contingency([]);) 2025.07.13 02:38:38.856930 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:38.954777 [ 32979 ] {9ffdf899-da15-4650-8d4e-7a0d1465af4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 1, should be 3: In scope SELECT convertCharset([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 355, line 356) (in query: SELECT convertCharset([]);) 2025.07.13 02:38:38.960706 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 1, should be 3: In scope SELECT convertCharset([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.054843 [ 32979 ] {cee1519b-5c79-4fd9-b5c7-5664827a0fbd} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 356, line 357) (in query: SELECT corr([]);) 2025.07.13 02:38:39.059775 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.103326 [ 32979 ] {e49430e2-cbd0-4569-9ec9-25fbd028374c} executeQuery: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 357, line 358) (in query: SELECT corrMatrix([]);) 2025.07.13 02:38:39.108210 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:39.138412 [ 32979 ] {9a7a5d54-24fb-4665-ae99-2aa5c380436b} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 358, line 359) (in query: SELECT corrStable([]);) 2025.07.13 02:38:39.144762 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.178469 [ 32979 ] {d5faab9a-ddd6-4878-a573-92a7e5cd93cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cos: In scope SELECT cos([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 359, line 360) (in query: SELECT cos([]);) 2025.07.13 02:38:39.184989 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cos: In scope SELECT cos([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:39.214883 [ 32979 ] {515a32df-81f9-4085-9737-c61dbf3c78e6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cosh: In scope SELECT cosh([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 360, line 361) (in query: SELECT cosh([]);) 2025.07.13 02:38:39.220115 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cosh: In scope SELECT cosh([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:39.256425 [ 32979 ] {9d5b5bf2-8806-454c-a92b-fe1bb75f21b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 1, should be 2: In scope SELECT cosineDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 361, line 362) (in query: SELECT cosineDistance([]);) 2025.07.13 02:38:39.261816 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 1, should be 2: In scope SELECT cosineDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.548801 [ 32979 ] {e9f0a962-43a1-4044-bb7b-66997d3bfb4f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countDigits: In scope SELECT countDigits([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 363, line 364) (in query: SELECT countDigits([]);) 2025.07.13 02:38:39.560561 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countDigits: In scope SELECT countDigits([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:39.603726 [ 32979 ] {9381af28-b67c-433c-821e-13466c219af1} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 1, should be 2: In scope SELECT countEqual([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 364, line 365) (in query: SELECT countEqual([]);) 2025.07.13 02:38:39.613342 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 1, should be 2: In scope SELECT countEqual([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.646737 [ 32979 ] {1aedc4a1-ec9b-4bf9-99ba-488dce69f39a} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 1, should be 2: In scope SELECT countMatches([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 365, line 366) (in query: SELECT countMatches([]);) 2025.07.13 02:38:39.651244 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 1, should be 2: In scope SELECT countMatches([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.678617 [ 32979 ] {5d15525e-0576-425e-9c8a-45f5565cfcfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT countMatchesCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 366, line 367) (in query: SELECT countMatchesCaseInsensitive([]);) 2025.07.13 02:38:39.682365 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT countMatchesCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.700062 [ 32979 ] {18483229-d7ae-448b-8fb3-e075e58f5934} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstrings([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 367, line 368) (in query: SELECT countSubstrings([]);) 2025.07.13 02:38:39.752314 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstrings([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.779291 [ 32979 ] {374f502e-ddb5-4a97-bdeb-c07c484104d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 368, line 369) (in query: SELECT countSubstringsCaseInsensitive([]);) 2025.07.13 02:38:39.784212 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.820679 [ 32979 ] {022aeb3d-2cb3-4ad8-93de-b7b221200895} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 369, line 370) (in query: SELECT countSubstringsCaseInsensitiveUTF8([]);) 2025.07.13 02:38:39.825527 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.852689 [ 32979 ] {2971e1db-8d3e-4492-847a-63aab7fdda5d} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 370, line 371) (in query: SELECT covarPop([]);) 2025.07.13 02:38:39.858609 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:39.928914 [ 32979 ] {345f3781-a241-4ac7-a5c3-8b50cc656215} executeQuery: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 371, line 372) (in query: SELECT covarPopMatrix([]);) 2025.07.13 02:38:39.936246 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:39.967770 [ 32979 ] {3d1b9d9f-ece4-4f16-a352-acad2bf6cbbd} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 372, line 373) (in query: SELECT covarPopStable([]);) 2025.07.13 02:38:39.973372 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.006953 [ 32979 ] {96acbf77-ca2e-4490-901f-f15ec2f3dd68} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 373, line 374) (in query: SELECT covarSamp([]);) 2025.07.13 02:38:40.015897 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.057879 [ 32979 ] {6c4649a8-1033-4ba5-81fd-d1cb4ba9f23a} executeQuery: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 374, line 375) (in query: SELECT covarSampMatrix([]);) 2025.07.13 02:38:40.067078 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:40.122896 [ 32979 ] {ad861072-0bb8-481e-aec4-e89dd3844af3} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 375, line 376) (in query: SELECT covarSampStable([]);) 2025.07.13 02:38:40.127809 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.172769 [ 32979 ] {7eb7cb49-e76c-48ab-8a3d-8a1322a44902} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 376, line 377) (in query: SELECT cramersV([]);) 2025.07.13 02:38:40.178787 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.207115 [ 32979 ] {07b5a5aa-2bc0-4ad7-b9b7-1b835870187c} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 377, line 378) (in query: SELECT cramersVBiasCorrected([]);) 2025.07.13 02:38:40.211121 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.266716 [ 32979 ] {d9744645-c644-4dcf-8ff3-a067aadc9ba2} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT curdate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 378, line 379) (in query: SELECT curdate([]);) 2025.07.13 02:38:40.270386 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT curdate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.311520 [ 32979 ] {01a50ca4-e433-43ba-b9b2-89487ce4178c} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT currentDatabase([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 379, line 380) (in query: SELECT currentDatabase([]);) 2025.07.13 02:38:40.317494 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT currentDatabase([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.356558 [ 32979 ] {8d7e5fbc-1175-4596-ac3c-e3d3a721e2a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 1, should be 0: In scope SELECT currentProfiles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 380, line 381) (in query: SELECT currentProfiles([]);) 2025.07.13 02:38:40.363829 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 1, should be 0: In scope SELECT currentProfiles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.386966 [ 32979 ] {c0032866-4945-4dc6-8c31-a376439f07d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT currentQueryID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 381, line 382) (in query: SELECT currentQueryID([]);) 2025.07.13 02:38:40.390879 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT currentQueryID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.430669 [ 32979 ] {834b00fb-5ce2-45be-aa06-4ed0d1e48413} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 1, should be 0: In scope SELECT currentRoles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 382, line 383) (in query: SELECT currentRoles([]);) 2025.07.13 02:38:40.436688 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 1, should be 0: In scope SELECT currentRoles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.473749 [ 32979 ] {0f60f80b-9619-4cfa-b87d-7372092532db} executeQuery: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT currentSchemas([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 383, line 384) (in query: SELECT currentSchemas([]);) 2025.07.13 02:38:40.477507 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT currentSchemas([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:40.593182 [ 32979 ] {c0324540-b3c0-4e50-aa41-9b84aa910854} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT currentUser([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 384, line 385) (in query: SELECT currentUser([]);) 2025.07.13 02:38:40.598435 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT currentUser([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.646743 [ 32979 ] {7b6633e1-9f27-453b-99e9-0fa3fe18473d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT current_database([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 385, line 386) (in query: SELECT current_database([]);) 2025.07.13 02:38:40.655735 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT current_database([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.793427 [ 32979 ] {d957bb9d-2e6a-4290-867d-0420e287b52e} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT current_date([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 386, line 387) (in query: SELECT current_date([]);) 2025.07.13 02:38:40.806246 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT current_date([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.850748 [ 32979 ] {97853593-db28-4428-881a-3c5bb1108da0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT current_query_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 387, line 388) (in query: SELECT current_query_id([]);) 2025.07.13 02:38:40.856161 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT current_query_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:40.876609 [ 32979 ] {7daeb87f-04eb-4142-b8ff-b8a440a757f6} executeQuery: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 388, line 389) (in query: SELECT current_schemas([]);) 2025.07.13 02:38:40.887538 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:40.921487 [ 32979 ] {98f9a742-d490-4239-ab20-a72711579d68} executeQuery: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT current_timestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 389, line 390) (in query: SELECT current_timestamp([]);) 2025.07.13 02:38:40.925206 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT current_timestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:40.947268 [ 32979 ] {9f3f396c-96b7-49bb-8217-fb9187b9f361} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT current_user([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 390, line 391) (in query: SELECT current_user([]);) 2025.07.13 02:38:40.953305 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT current_user([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.014631 [ 32979 ] {a116bff0-b0b4-41aa-a2c1-1f431cff9644} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutFragment: In scope SELECT cutFragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 391, line 392) (in query: SELECT cutFragment([]);) 2025.07.13 02:38:41.018803 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutFragment: In scope SELECT cutFragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.039544 [ 32979 ] {e1f705e5-098e-45a8-96ca-4cc03da4832e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 1, should be 3: In scope SELECT cutIPv6([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 392, line 393) (in query: SELECT cutIPv6([]);) 2025.07.13 02:38:41.041864 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 1, should be 3: In scope SELECT cutIPv6([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.125454 [ 32979 ] {5aca04e1-b865-442a-aaf3-37584eefd627} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutQueryString: In scope SELECT cutQueryString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 393, line 394) (in query: SELECT cutQueryString([]);) 2025.07.13 02:38:41.131783 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutQueryString: In scope SELECT cutQueryString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.163214 [ 32979 ] {a3ba2fb9-1d84-4a34-b045-5cdfa1e40ea2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutQueryStringAndFragment: In scope SELECT cutQueryStringAndFragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 394, line 395) (in query: SELECT cutQueryStringAndFragment([]);) 2025.07.13 02:38:41.170731 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutQueryStringAndFragment: In scope SELECT cutQueryStringAndFragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.203090 [ 32979 ] {bcb91770-c2f1-4ec5-a996-29027a98949b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomain: In scope SELECT cutToFirstSignificantSubdomain([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 395, line 396) (in query: SELECT cutToFirstSignificantSubdomain([]);) 2025.07.13 02:38:41.212717 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomain: In scope SELECT cutToFirstSignificantSubdomain([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.240173 [ 32979 ] {43a2695c-ee20-4f14-8742-0f60f2f5d43d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 396, line 397) (in query: SELECT cutToFirstSignificantSubdomainCustom([]);) 2025.07.13 02:38:41.245434 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.289234 [ 32979 ] {2fbd004c-3578-4857-86fd-4b463f398733} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC([]);) 2025.07.13 02:38:41.296389 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.348467 [ 32979 ] {ea83d4ef-64f4-4aca-9afa-7a2736ef8044} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW([]);) 2025.07.13 02:38:41.352666 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.383936 [ 32979 ] {602c7992-2627-48e5-bfd6-46f9b0076ec2} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([]);) 2025.07.13 02:38:41.387517 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.409490 [ 32979 ] {e7c4d466-7a3a-409b-bdd0-85c9261cfd96} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomainRFC: In scope SELECT cutToFirstSignificantSubdomainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC([]);) 2025.07.13 02:38:41.412750 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomainRFC: In scope SELECT cutToFirstSignificantSubdomainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.427597 [ 32979 ] {7b1e30f3-3dba-40cd-9fb5-1aea0bef5762} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomainWithWWW: In scope SELECT cutToFirstSignificantSubdomainWithWWW([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW([]);) 2025.07.13 02:38:41.430138 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomainWithWWW: In scope SELECT cutToFirstSignificantSubdomainWithWWW([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.451060 [ 32979 ] {addbe09a-a4e2-4bb8-8a98-78603899fde6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomainWithWWWRFC: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC([]);) 2025.07.13 02:38:41.454218 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutToFirstSignificantSubdomainWithWWWRFC: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.469085 [ 32979 ] {1f060ce8-62c2-4450-96ce-9ad84cbda5c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 1, should be 2: In scope SELECT cutURLParameter([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 403, line 404) (in query: SELECT cutURLParameter([]);) 2025.07.13 02:38:41.472238 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 1, should be 2: In scope SELECT cutURLParameter([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.486518 [ 32979 ] {4e5e543f-d354-4720-b490-e0cf3f7c5b5a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutWWW: In scope SELECT cutWWW([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 404, line 405) (in query: SELECT cutWWW([]);) 2025.07.13 02:38:41.499284 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutWWW: In scope SELECT cutWWW([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.521283 [ 32979 ] {84514ab9-79d7-449a-84ae-c54abadfe034} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 1, should be 2: In scope SELECT damerauLevenshteinDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 405, line 406) (in query: SELECT damerauLevenshteinDistance([]);) 2025.07.13 02:38:41.523862 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 1, should be 2: In scope SELECT damerauLevenshteinDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.538851 [ 32979 ] {0e24e0bf-3233-42e4-bf7d-06462ba1338f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 406, line 407) (in query: SELECT dateDiff([]);) 2025.07.13 02:38:41.542236 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.556951 [ 32979 ] {558e81bd-4917-4a7d-85d0-6d5bbf0dbbe6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 1: In scope SELECT dateName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 407, line 408) (in query: SELECT dateName([]);) 2025.07.13 02:38:41.560578 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 1: In scope SELECT dateName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:41.576185 [ 32979 ] {5a617c8d-6274-494c-9bb7-47f4e627a933} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: Array(Nothing): In scope SELECT dateTime64ToSnowflake([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 408, line 409) (in query: SELECT dateTime64ToSnowflake([]);) 2025.07.13 02:38:41.589329 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: Array(Nothing): In scope SELECT dateTime64ToSnowflake([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.609570 [ 32979 ] {bcf4c5d0-ae1b-4dbe-8e66-5959608897d5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: Array(Nothing): In scope SELECT dateTime64ToSnowflakeID([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 409, line 410) (in query: SELECT dateTime64ToSnowflakeID([]);) 2025.07.13 02:38:41.614814 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: Array(Nothing): In scope SELECT dateTime64ToSnowflakeID([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.823822 [ 32979 ] {505d3dfe-aa00-4a25-bced-96ce99a22329} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: Array(Nothing): In scope SELECT dateTimeToSnowflake([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 410, line 411) (in query: SELECT dateTimeToSnowflake([]);) 2025.07.13 02:38:41.917653 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: Array(Nothing): In scope SELECT dateTimeToSnowflake([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.947325 [ 32979 ] {edddae79-0ec3-4fc3-990c-7057df2b5d13} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: Array(Nothing): In scope SELECT dateTimeToSnowflakeID([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 411, line 412) (in query: SELECT dateTimeToSnowflakeID([]);) 2025.07.13 02:38:41.953372 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: Array(Nothing): In scope SELECT dateTimeToSnowflakeID([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:41.986586 [ 32979 ] {9ccd9b09-514a-4b35-ab53-36840a73c9dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT dateTrunc([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 412, line 413) (in query: SELECT dateTrunc([]);) 2025.07.13 02:38:41.996322 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT dateTrunc([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.083303 [ 32979 ] {40fe8218-50df-4d1a-8b72-2e3c27c550ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT date_bin([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 413, line 414) (in query: SELECT date_bin([]);) 2025.07.13 02:38:42.086413 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT date_bin([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.135413 [ 32979 ] {b4d28292-46c1-4e8a-80a3-5d770502c546} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 414, line 415) (in query: SELECT date_diff([]);) 2025.07.13 02:38:42.141391 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.192463 [ 32979 ] {2c8b41c9-7217-462d-a0ac-96ead8f0e4e8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeHTMLComponent: In scope SELECT decodeHTMLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 415, line 416) (in query: SELECT decodeHTMLComponent([]);) 2025.07.13 02:38:42.197293 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeHTMLComponent: In scope SELECT decodeHTMLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.215041 [ 32979 ] {d9bf5bf6-155f-4136-a836-c165cf5a2375} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeURLComponent: In scope SELECT decodeURLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 416, line 417) (in query: SELECT decodeURLComponent([]);) 2025.07.13 02:38:42.218546 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeURLComponent: In scope SELECT decodeURLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.258057 [ 32979 ] {bfa63b55-1ba4-443f-916c-0244e35ed8fe} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeURLFormComponent: In scope SELECT decodeURLFormComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 417, line 418) (in query: SELECT decodeURLFormComponent([]);) 2025.07.13 02:38:42.262135 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeURLFormComponent: In scope SELECT decodeURLFormComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.295785 [ 32979 ] {dc0c411f-c77f-4b5e-9db0-b37bb874b309} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeXMLComponent: In scope SELECT decodeXMLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 418, line 419) (in query: SELECT decodeXMLComponent([]);) 2025.07.13 02:38:42.301416 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function decodeXMLComponent: In scope SELECT decodeXMLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.357567 [ 32979 ] {b024a8e7-151d-401d-8766-cc8a76994918} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT decrypt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 419, line 420) (in query: SELECT decrypt([]);) 2025.07.13 02:38:42.360892 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT decrypt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.386609 [ 32979 ] {540c43a7-c8bc-4594-a661-996b511c86e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 1, should be 0: In scope SELECT defaultProfiles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 420, line 421) (in query: SELECT defaultProfiles([]);) 2025.07.13 02:38:42.390250 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 1, should be 0: In scope SELECT defaultProfiles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.406639 [ 32979 ] {8b7add53-1f6b-4217-9808-3c35a336bca0} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 1, should be 0: In scope SELECT defaultRoles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 421, line 422) (in query: SELECT defaultRoles([]);) 2025.07.13 02:38:42.409317 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 1, should be 0: In scope SELECT defaultRoles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.505560 [ 32979 ] {7cf78ff9-d4c9-455a-a86c-fceb2afd5261} executeQuery: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 423, line 424) (in query: SELECT defaultValueOfTypeName([]);) 2025.07.13 02:38:42.509490 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName([]). (ILLEGAL_COLUMN) 2025.07.13 02:38:42.529521 [ 32979 ] {58ceeada-f75c-4b4d-8a3a-25906592538b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function degrees: In scope SELECT degrees([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 424, line 425) (in query: SELECT degrees([]);) 2025.07.13 02:38:42.532828 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function degrees: In scope SELECT degrees([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.559703 [ 32979 ] {595b2bb9-c90d-4800-b781-953733b843c6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function deltaSum. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 425, line 426) (in query: SELECT deltaSum([]);) 2025.07.13 02:38:42.564316 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function deltaSum. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.590806 [ 32979 ] {9d9249f5-b117-4e2b-b46d-47b39b7c1f1c} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 426, line 427) (in query: SELECT deltaSumTimestamp([]);) 2025.07.13 02:38:42.595391 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:42.648400 [ 32979 ] {a9717c7e-52e0-4928-aade-a531ee9e6f47} executeQuery: Code: 43. DB::Exception: The only argument for function demangle must be String. Found Array(Nothing) instead.: In scope SELECT demangle([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 427, line 428) (in query: SELECT demangle([]);) 2025.07.13 02:38:42.653420 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function demangle must be String. Found Array(Nothing) instead.: In scope SELECT demangle([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:42.730581 [ 32979 ] {463ec11d-fa60-4fe9-a8d1-c9fda77a801d} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 428, line 429) (in query: SELECT denseRank([]);) 2025.07.13 02:38:42.735101 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:38:42.785905 [ 32979 ] {7ed28158-12b4-4cc4-9e8c-6835128c5328} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 429, line 430) (in query: SELECT dense_rank([]);) 2025.07.13 02:38:42.791078 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:38:42.817779 [ 32979 ] {16f0b8c6-bdc4-4e5d-a3a4-ffa04280eb20} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 430, line 431) (in query: SELECT detectCharset([]);) 2025.07.13 02:38:42.823564 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:38:42.862379 [ 32979 ] {0803cc8e-c774-4b99-81b6-84a6616baa04} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 431, line 432) (in query: SELECT detectLanguage([]);) 2025.07.13 02:38:42.868406 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:38:42.961581 [ 32979 ] {6f2dee83-cef1-4a60-b1e8-223956f4cb77} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 432, line 433) (in query: SELECT detectLanguageMixed([]);) 2025.07.13 02:38:42.968914 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:38:43.006107 [ 32979 ] {ea8a6991-912c-4a53-b825-001d8d00dc05} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 433, line 434) (in query: SELECT detectLanguageUnknown([]);) 2025.07.13 02:38:43.013028 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:38:43.076026 [ 32979 ] {014f1526-95e9-4d18-b7a2-e471d072e206} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 434, line 435) (in query: SELECT detectProgrammingLanguage([]);) 2025.07.13 02:38:43.081473 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:38:43.124233 [ 32979 ] {43661cbf-61f2-4465-af82-e99951b5c52c} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 435, line 436) (in query: SELECT detectTonality([]);) 2025.07.13 02:38:43.130271 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:38:43.210674 [ 32979 ] {24f52637-1239-4b3e-bf40-5be105c55123} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 436, line 437) (in query: SELECT dictGet([]);) 2025.07.13 02:38:43.217031 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.248096 [ 32979 ] {8f6ecfc5-ae10-43c8-876e-a69693c3d19f} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 437, line 438) (in query: SELECT dictGetAll([]);) 2025.07.13 02:38:43.253828 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.288420 [ 32979 ] {2e4f6f65-4409-4d70-8108-c4568b6dd9e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 1, should be 2: In scope SELECT dictGetChildren([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 438, line 439) (in query: SELECT dictGetChildren([]);) 2025.07.13 02:38:43.295236 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 1, should be 2: In scope SELECT dictGetChildren([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.328032 [ 32979 ] {40fcfd8e-78fc-4389-afeb-a257edec9154} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 439, line 440) (in query: SELECT dictGetDate([]);) 2025.07.13 02:38:43.334823 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.380587 [ 32979 ] {377b0c27-3269-40c8-a5bc-42250165bc3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 440, line 441) (in query: SELECT dictGetDateOrDefault([]);) 2025.07.13 02:38:43.387398 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.443932 [ 32979 ] {dffd5fb6-de25-45e0-b4ae-24b0fad3be53} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 441, line 442) (in query: SELECT dictGetDateTime([]);) 2025.07.13 02:38:43.458773 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.504928 [ 32979 ] {a8b4a2bc-e451-4339-adf0-0b0b1dd580af} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 442, line 443) (in query: SELECT dictGetDateTimeOrDefault([]);) 2025.07.13 02:38:43.511283 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.543739 [ 32979 ] {3870e2e6-a23d-46a0-9a8b-5bd4715a9a25} executeQuery: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 1: In scope SELECT dictGetDescendants([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 443, line 444) (in query: SELECT dictGetDescendants([]);) 2025.07.13 02:38:43.548535 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 1: In scope SELECT dictGetDescendants([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.589554 [ 32979 ] {4f3d66cd-1a8c-41da-8ceb-383f6a645c5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 444, line 445) (in query: SELECT dictGetFloat32([]);) 2025.07.13 02:38:43.594369 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.618680 [ 32979 ] {122f4ee9-ab72-49fc-b84e-3627dd4e280a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 445, line 446) (in query: SELECT dictGetFloat32OrDefault([]);) 2025.07.13 02:38:43.630828 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.674148 [ 32979 ] {63f8390e-9d51-4ccd-bdb8-c69c25a88e08} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 446, line 447) (in query: SELECT dictGetFloat64([]);) 2025.07.13 02:38:43.757238 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.807175 [ 32979 ] {dbb575fc-f354-4a65-8571-650667be87a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 447, line 448) (in query: SELECT dictGetFloat64OrDefault([]);) 2025.07.13 02:38:43.822775 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.863457 [ 32979 ] {36f3b5cb-d00a-4bbd-9787-9fe6cf738902} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 1, should be 2: In scope SELECT dictGetHierarchy([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 448, line 449) (in query: SELECT dictGetHierarchy([]);) 2025.07.13 02:38:43.868965 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 1, should be 2: In scope SELECT dictGetHierarchy([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:43.904788 [ 32979 ] {cdd32e6e-3319-4229-8c87-a5ff23cbef1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 449, line 450) (in query: SELECT dictGetIPv4([]);) 2025.07.13 02:38:43.921144 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.028315 [ 32979 ] {51c55eaa-67de-4908-8aa6-b1b65a0ec96f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 450, line 451) (in query: SELECT dictGetIPv4OrDefault([]);) 2025.07.13 02:38:44.034739 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.084206 [ 32979 ] {8de9600b-6c0d-45e0-96e8-9893e4bccbfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 451, line 452) (in query: SELECT dictGetIPv6([]);) 2025.07.13 02:38:44.090187 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.135784 [ 32979 ] {23bafdeb-2baa-4e4f-aac3-c8139c1e0df3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 452, line 453) (in query: SELECT dictGetIPv6OrDefault([]);) 2025.07.13 02:38:44.141547 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.168060 [ 32979 ] {d6a7ac1e-d6e9-4eec-9415-4450038fa980} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 453, line 454) (in query: SELECT dictGetInt16([]);) 2025.07.13 02:38:44.171830 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.225106 [ 32979 ] {42afa27f-4d49-4aa1-afa5-3671efe3d8f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 454, line 455) (in query: SELECT dictGetInt16OrDefault([]);) 2025.07.13 02:38:44.231956 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.264877 [ 32979 ] {0d489e9c-aa26-4327-90a1-a2e445022282} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 455, line 456) (in query: SELECT dictGetInt32([]);) 2025.07.13 02:38:44.269935 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.297160 [ 32979 ] {4858a9d9-3404-46e3-bbde-08fa2e3333f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 456, line 457) (in query: SELECT dictGetInt32OrDefault([]);) 2025.07.13 02:38:44.303119 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.328476 [ 32979 ] {3fb2eb17-7303-42d5-8205-26d3f4d6c7e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 457, line 458) (in query: SELECT dictGetInt64([]);) 2025.07.13 02:38:44.333306 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.363440 [ 32979 ] {ca002467-bfdc-46ca-8d34-e9542b6c37a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 458, line 459) (in query: SELECT dictGetInt64OrDefault([]);) 2025.07.13 02:38:44.369412 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.407073 [ 32979 ] {f8462ff5-ce7d-4db6-a094-ab2706082e93} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 459, line 460) (in query: SELECT dictGetInt8([]);) 2025.07.13 02:38:44.411775 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.473963 [ 32979 ] {0e766916-b129-4252-ae46-1b894188433e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 460, line 461) (in query: SELECT dictGetInt8OrDefault([]);) 2025.07.13 02:38:44.517683 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.539180 [ 32979 ] {9c78f64a-e7f2-4754-939f-84cd7d8b14dd} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 461, line 462) (in query: SELECT dictGetOrDefault([]);) 2025.07.13 02:38:44.543767 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.572966 [ 32979 ] {25fcad30-5697-4448-9ae4-80601892beda} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 462, line 463) (in query: SELECT dictGetOrNull([]);) 2025.07.13 02:38:44.579283 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.619776 [ 32979 ] {f1be7787-4173-4052-b48e-9219c40a65ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 463, line 464) (in query: SELECT dictGetString([]);) 2025.07.13 02:38:44.625618 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.655287 [ 32979 ] {95fb0e38-d8c8-4069-83d7-e0b4db3cd2a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 464, line 465) (in query: SELECT dictGetStringOrDefault([]);) 2025.07.13 02:38:44.660244 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.771566 [ 32979 ] {b4d959ce-6b04-43c0-ae25-c4c3fd3e35ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 465, line 466) (in query: SELECT dictGetUInt16([]);) 2025.07.13 02:38:44.775539 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.807904 [ 32979 ] {45cc7d8e-ddc5-4777-b692-44d630285c35} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 466, line 467) (in query: SELECT dictGetUInt16OrDefault([]);) 2025.07.13 02:38:44.812509 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.847479 [ 32979 ] {0c270b8b-b95a-4fcf-b375-c793acaeca83} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 467, line 468) (in query: SELECT dictGetUInt32([]);) 2025.07.13 02:38:44.852360 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.905119 [ 32979 ] {416770ad-9de3-4d71-a64f-8457a45bc406} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 468, line 469) (in query: SELECT dictGetUInt32OrDefault([]);) 2025.07.13 02:38:44.908094 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.926411 [ 32979 ] {7724ec47-e00d-47f7-b854-a8bfd9a29bf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 469, line 470) (in query: SELECT dictGetUInt64([]);) 2025.07.13 02:38:44.929108 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:44.975702 [ 32979 ] {49697fd3-e44e-4914-bcf9-3d92c93eb3c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 470, line 471) (in query: SELECT dictGetUInt64OrDefault([]);) 2025.07.13 02:38:44.982508 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.010291 [ 32979 ] {e0e54482-608e-4e18-939d-133f3cb03cc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 471, line 472) (in query: SELECT dictGetUInt8([]);) 2025.07.13 02:38:45.015145 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.044190 [ 32979 ] {3989a453-6680-4b93-9d42-a2a030fc69ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 472, line 473) (in query: SELECT dictGetUInt8OrDefault([]);) 2025.07.13 02:38:45.050021 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.092344 [ 32979 ] {6fbff588-544f-40e2-a648-4e5d591e749f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 473, line 474) (in query: SELECT dictGetUUID([]);) 2025.07.13 02:38:45.096559 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.138781 [ 32979 ] {415c06b3-1eee-4240-afe0-b8fc7def73ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 474, line 475) (in query: SELECT dictGetUUIDOrDefault([]);) 2025.07.13 02:38:45.144448 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.174315 [ 32979 ] {8f56dd8b-38fa-46cc-80f6-978138c1dd3b} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 475, line 476) (in query: SELECT dictHas([]);) 2025.07.13 02:38:45.180608 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.207734 [ 32979 ] {faf5660f-9a85-43ea-bd61-56f1b6efb103} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 1, should be 3: In scope SELECT dictIsIn([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 476, line 477) (in query: SELECT dictIsIn([]);) 2025.07.13 02:38:45.210698 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 1, should be 3: In scope SELECT dictIsIn([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.229471 [ 32979 ] {be2c1bd8-5cf3-4fdf-ba9b-c0e849fc87e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 1, should be 0: In scope SELECT displayName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 477, line 478) (in query: SELECT displayName([]);) 2025.07.13 02:38:45.233472 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 1, should be 0: In scope SELECT displayName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.353635 [ 32979 ] {d3b7d7f5-7f60-4fae-8b17-8f726ae5d026} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL1([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 478, line 479) (in query: SELECT distanceL1([]);) 2025.07.13 02:38:45.360089 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL1([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.446138 [ 32979 ] {99cc88d9-5745-476b-97fd-d4eb6b6f2c7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 479, line 480) (in query: SELECT distanceL2([]);) 2025.07.13 02:38:45.453468 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.539229 [ 32979 ] {81112065-7617-434c-89e1-ec601376415b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT distanceL2Squared([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 480, line 481) (in query: SELECT distanceL2Squared([]);) 2025.07.13 02:38:45.543730 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT distanceL2Squared([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.565903 [ 32979 ] {9eeba928-3196-4be0-a986-7a8b0c0233c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT distanceLinf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 481, line 482) (in query: SELECT distanceLinf([]);) 2025.07.13 02:38:45.570352 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT distanceLinf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.612029 [ 32979 ] {13646b41-ec8c-4a93-af3c-189b09ba7767} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT distanceLp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 482, line 483) (in query: SELECT distanceLp([]);) 2025.07.13 02:38:45.618184 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT distanceLp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.660935 [ 32979 ] {8d0c47be-ee05-4edc-9676-7d37ebf48cf8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function distinctDynamicTypes. Expected type Dynamic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 483, line 484) (in query: SELECT distinctDynamicTypes([]);) 2025.07.13 02:38:45.666692 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function distinctDynamicTypes. Expected type Dynamic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:45.720571 [ 32979 ] {3e808579-9855-473e-b804-adaeccedb174} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function distinctJSONPaths. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 484, line 485) (in query: SELECT distinctJSONPaths([]);) 2025.07.13 02:38:45.726671 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function distinctJSONPaths. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:45.797454 [ 32979 ] {b544a46a-7451-49d9-a576-b93f7e068364} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function distinctJSONPathsAndTypes. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 485, line 486) (in query: SELECT distinctJSONPathsAndTypes([]);) 2025.07.13 02:38:45.803062 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function distinctJSONPathsAndTypes. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:45.844829 [ 32979 ] {a0c1c007-76b4-4a37-a59e-a381b050789d} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 1, should be 2: In scope SELECT divide([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 486, line 487) (in query: SELECT divide([]);) 2025.07.13 02:38:45.865310 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 1, should be 2: In scope SELECT divide([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:45.912839 [ 32979 ] {5c1cc649-06f5-4bbd-bddf-1b1870e3e848} executeQuery: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 487, line 488) (in query: SELECT divideDecimal([]);) 2025.07.13 02:38:45.918435 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:46.026208 [ 32979 ] {9c0bf0ce-16fa-44dc-890f-183b8bc4a0b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domain: In scope SELECT domain([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 488, line 489) (in query: SELECT domain([]);) 2025.07.13 02:38:46.043430 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domain: In scope SELECT domain([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:46.077706 [ 32979 ] {54dc98de-98f0-404f-944c-ecf8c5d19906} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domainRFC: In scope SELECT domainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 489, line 490) (in query: SELECT domainRFC([]);) 2025.07.13 02:38:46.085061 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domainRFC: In scope SELECT domainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:46.232618 [ 32979 ] {626910d5-b17d-4600-8204-af001043d746} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domainWithoutWWW: In scope SELECT domainWithoutWWW([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 490, line 491) (in query: SELECT domainWithoutWWW([]);) 2025.07.13 02:38:46.238569 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domainWithoutWWW: In scope SELECT domainWithoutWWW([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:46.298883 [ 32979 ] {69cebf40-dbef-47c1-8042-22b5eb0c8ae4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domainWithoutWWWRFC: In scope SELECT domainWithoutWWWRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 491, line 492) (in query: SELECT domainWithoutWWWRFC([]);) 2025.07.13 02:38:46.310345 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function domainWithoutWWWRFC: In scope SELECT domainWithoutWWWRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:46.355251 [ 32979 ] {f94113ab-4baa-443d-a0a4-78ff5e15c4ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT dotProduct([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 492, line 493) (in query: SELECT dotProduct([]);) 2025.07.13 02:38:46.361873 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT dotProduct([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:46.589666 [ 32979 ] {6d6b9dd8-9124-4b8f-9683-b79dd96c9b71} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 1, should be 2: In scope SELECT dynamicElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 494, line 495) (in query: SELECT dynamicElement([]);) 2025.07.13 02:38:46.598589 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 1, should be 2: In scope SELECT dynamicElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:46.621724 [ 32979 ] {fa9ccbbc-9f3a-4d43-b330-04005401386d} executeQuery: Code: 43. DB::Exception: First argument for function dynamicType must be Dynamic, got Array(Nothing) instead: In scope SELECT dynamicType([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 495, line 496) (in query: SELECT dynamicType([]);) 2025.07.13 02:38:46.626126 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicType must be Dynamic, got Array(Nothing) instead: In scope SELECT dynamicType([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:46.664339 [ 32979 ] {b45cf521-8fa1-4c42-9959-27a712125bb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 1, should be 0: In scope SELECT e([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 496, line 497) (in query: SELECT e([]);) 2025.07.13 02:38:46.671584 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 1, should be 0: In scope SELECT e([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:46.693162 [ 32979 ] {6f7a2995-4f43-4208-9f30-9e0761647f65} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT editDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 497, line 498) (in query: SELECT editDistance([]);) 2025.07.13 02:38:46.699076 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT editDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:46.755696 [ 32979 ] {92abadcf-026e-4b34-b989-1ef9d36ea4a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT editDistanceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 498, line 499) (in query: SELECT editDistanceUTF8([]);) 2025.07.13 02:38:46.760947 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT editDistanceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:46.908360 [ 32979 ] {0250e7cc-8a76-4d08-9ec8-741ef1217602} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 500, line 501) (in query: SELECT emptyArrayDate([]);) 2025.07.13 02:38:46.914503 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.058694 [ 32979 ] {5c1b1311-ee24-4b6f-a791-996bd671c35f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 501, line 502) (in query: SELECT emptyArrayDateTime([]);) 2025.07.13 02:38:47.061943 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.139164 [ 32979 ] {92a83de4-01ab-4117-bdeb-61f9abfcf657} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 502, line 503) (in query: SELECT emptyArrayFloat32([]);) 2025.07.13 02:38:47.145645 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.177122 [ 32979 ] {71047006-7058-4782-a3b6-da6788bd26eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 503, line 504) (in query: SELECT emptyArrayFloat64([]);) 2025.07.13 02:38:47.199276 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.231658 [ 32979 ] {0073ba1b-868c-4291-b498-c050fd5f5a10} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 504, line 505) (in query: SELECT emptyArrayInt16([]);) 2025.07.13 02:38:47.237803 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.277234 [ 32979 ] {fb8bd11b-53d3-421c-b380-b9cd2b3bfa44} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 505, line 506) (in query: SELECT emptyArrayInt32([]);) 2025.07.13 02:38:47.283079 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.319907 [ 32979 ] {e27555f2-a0b7-43ae-85d6-c1ff72b8d848} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 506, line 507) (in query: SELECT emptyArrayInt64([]);) 2025.07.13 02:38:47.330486 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.363864 [ 32979 ] {37c50d40-d80b-423e-af19-844f8b492a1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 507, line 508) (in query: SELECT emptyArrayInt8([]);) 2025.07.13 02:38:47.369335 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.410425 [ 32979 ] {f78b0e8e-1ab3-4256-b6ea-893f74f05abc} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 1, should be 0: In scope SELECT emptyArrayString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 508, line 509) (in query: SELECT emptyArrayString([]);) 2025.07.13 02:38:47.417603 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 1, should be 0: In scope SELECT emptyArrayString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.539575 [ 32979 ] {1c5d0fda-152e-4bcf-954a-30f0be295d1a} executeQuery: Code: 48. DB::Exception: Cannot get value from Nothing. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 509, line 510) (in query: SELECT emptyArrayToSingle([]);) 2025.07.13 02:38:47.547870 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: Cannot get value from Nothing. (NOT_IMPLEMENTED) 2025.07.13 02:38:47.664594 [ 32979 ] {b7faed31-8515-4b0e-9e46-ce424d917dba} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 510, line 511) (in query: SELECT emptyArrayUInt16([]);) 2025.07.13 02:38:47.669219 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt16([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.706693 [ 32979 ] {6e8e4d10-13c5-404e-bc75-2b7c8c2354ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 511, line 512) (in query: SELECT emptyArrayUInt32([]);) 2025.07.13 02:38:47.716697 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.752898 [ 32979 ] {5690ee98-3343-4665-8425-24a3c18bc51c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt64([]);) 2025.07.13 02:38:47.766599 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.882875 [ 32979 ] {856761fb-af77-4826-bc81-6ee3e0d655ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt8([]);) 2025.07.13 02:38:47.889072 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.929659 [ 32979 ] {9b7b1d59-8549-486d-a629-26d738df04f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 1, should be 0: In scope SELECT enabledProfiles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 514, line 515) (in query: SELECT enabledProfiles([]);) 2025.07.13 02:38:47.934990 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 1, should be 0: In scope SELECT enabledProfiles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:47.967589 [ 32979 ] {c3ef6f92-37ff-41d0-906f-1e2b63519a4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 1, should be 0: In scope SELECT enabledRoles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 515, line 516) (in query: SELECT enabledRoles([]);) 2025.07.13 02:38:47.975497 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 1, should be 0: In scope SELECT enabledRoles([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:48.005559 [ 32979 ] {48f18c99-7d0c-4fe3-becf-88fd8530763e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function encodeURLComponent: In scope SELECT encodeURLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 516, line 517) (in query: SELECT encodeURLComponent([]);) 2025.07.13 02:38:48.016472 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function encodeURLComponent: In scope SELECT encodeURLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:48.053926 [ 32979 ] {92428b74-386b-49dc-b0cd-42941816bfa1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function encodeURLFormComponent: In scope SELECT encodeURLFormComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 517, line 518) (in query: SELECT encodeURLFormComponent([]);) 2025.07.13 02:38:48.061981 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function encodeURLFormComponent: In scope SELECT encodeURLFormComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:48.096614 [ 32979 ] {727cf901-30c1-4326-823c-5acf5f57cbec} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function encodeXMLComponent: In scope SELECT encodeXMLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 518, line 519) (in query: SELECT encodeXMLComponent([]);) 2025.07.13 02:38:48.101371 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function encodeXMLComponent: In scope SELECT encodeXMLComponent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:48.138600 [ 32979 ] {861e7413-7d98-45c5-bd86-eb3f08870a78} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT encrypt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 519, line 520) (in query: SELECT encrypt([]);) 2025.07.13 02:38:48.145923 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT encrypt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:48.281138 [ 32979 ] {aa76b0ee-05ee-4662-a46e-4b934373e04c} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 1, should be 2: In scope SELECT endsWith([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 520, line 521) (in query: SELECT endsWith([]);) 2025.07.13 02:38:48.295201 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 1, should be 2: In scope SELECT endsWith([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:48.323360 [ 32979 ] {0328aaa7-9c99-4505-998d-81ff5715c662} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT endsWithUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 521, line 522) (in query: SELECT endsWithUTF8([]);) 2025.07.13 02:38:48.327550 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT endsWithUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:48.591398 [ 32979 ] {169d1e8e-bb6d-4596-89bc-48d6791f99a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT equals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 523, line 524) (in query: SELECT equals([]);) 2025.07.13 02:38:48.605334 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT equals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:48.658622 [ 32979 ] {93c101f4-74c7-4716-93ee-e2cb863c3d1b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function erf: In scope SELECT erf([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 524, line 525) (in query: SELECT erf([]);) 2025.07.13 02:38:48.666837 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function erf: In scope SELECT erf([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:48.720063 [ 32979 ] {14bdfd41-01bd-46be-8e26-44b8a837bf29} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function erfc: In scope SELECT erfc([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 525, line 526) (in query: SELECT erfc([]);) 2025.07.13 02:38:48.727124 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function erfc: In scope SELECT erfc([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:48.757206 [ 32979 ] {5fbba617-d48c-4fa5-8cdf-ef0b1dd61d2f} executeQuery: Code: 36. DB::Exception: The argument of function errorCodeToName must have simple numeric type, possibly Nullable: In scope SELECT errorCodeToName([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 526, line 527) (in query: SELECT errorCodeToName([]);) 2025.07.13 02:38:48.761072 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The argument of function errorCodeToName must have simple numeric type, possibly Nullable: In scope SELECT errorCodeToName([]). (BAD_ARGUMENTS) 2025.07.13 02:38:48.998693 [ 32979 ] {c3efe927-c58f-426d-9bae-3b00807fd507} executeQuery: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 528, line 529) (in query: SELECT evalMLMethod([]);) 2025.07.13 02:38:49.012542 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:49.065849 [ 32979 ] {81b4db9d-c52f-4bd5-8933-c5a9b0627b60} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function exp: In scope SELECT exp([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 529, line 530) (in query: SELECT exp([]);) 2025.07.13 02:38:49.149537 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function exp: In scope SELECT exp([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:49.279942 [ 32979 ] {faf971a5-9080-446a-9b5f-56bfc30caed9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function exp10: In scope SELECT exp10([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 530, line 531) (in query: SELECT exp10([]);) 2025.07.13 02:38:49.285379 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function exp10: In scope SELECT exp10([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:49.312604 [ 32979 ] {dbd1c889-474f-4b3a-8963-9935dc92c1e6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function exp2: In scope SELECT exp2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 531, line 532) (in query: SELECT exp2([]);) 2025.07.13 02:38:49.326551 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function exp2: In scope SELECT exp2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:49.368837 [ 32979 ] {d53aa4f7-477d-4e2f-b53b-88564af00f4a} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 532, line 533) (in query: SELECT exponentialMovingAverage([]);) 2025.07.13 02:38:49.385016 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.420543 [ 32979 ] {587df823-365f-434b-9548-050f30276662} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 533, line 534) (in query: SELECT exponentialTimeDecayedAvg([]);) 2025.07.13 02:38:49.426080 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.469047 [ 32979 ] {24be6f77-cb81-4587-8ffa-35231f253697} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 534, line 535) (in query: SELECT exponentialTimeDecayedCount([]);) 2025.07.13 02:38:49.479774 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.525776 [ 32979 ] {1f7579c7-fcdc-44fa-a74c-40a4b8418f37} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedMax([]);) 2025.07.13 02:38:49.530226 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.565125 [ 32979 ] {6144729d-9816-48cc-9fc0-f101204d9404} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedSum([]);) 2025.07.13 02:38:49.571713 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.622228 [ 32979 ] {49e62a15-170c-4801-9caa-799518c3d425} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 1, should be 2: In scope SELECT extract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 537, line 538) (in query: SELECT extract([]);) 2025.07.13 02:38:49.628063 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 1, should be 2: In scope SELECT extract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.677693 [ 32979 ] {ba0d5f5d-059a-4ab5-b87b-a16e07ee00f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 1, should be 2: In scope SELECT extractAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 538, line 539) (in query: SELECT extractAll([]);) 2025.07.13 02:38:49.684066 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 1, should be 2: In scope SELECT extractAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.721788 [ 32979 ] {7057a43d-b801-4bdb-a9d2-36ec2e9bdefe} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroups([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 539, line 540) (in query: SELECT extractAllGroups([]);) 2025.07.13 02:38:49.727574 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroups([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.754922 [ 32979 ] {3ac474ef-169b-45fe-a4c0-236e039ba5af} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 540, line 541) (in query: SELECT extractAllGroupsHorizontal([]);) 2025.07.13 02:38:49.758425 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.804819 [ 32979 ] {0392e6f9-4e6a-4f2d-8b8b-178231da6d19} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsVertical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 541, line 542) (in query: SELECT extractAllGroupsVertical([]);) 2025.07.13 02:38:49.810669 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsVertical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.849623 [ 32979 ] {c12bded3-09da-4ff7-b4b8-c0c46ae66673} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 542, line 543) (in query: SELECT extractGroups([]);) 2025.07.13 02:38:49.854069 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:49.950044 [ 32979 ] {b324440b-f904-42d3-af90-500503da0bff} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 543, line 544) (in query: SELECT extractKeyValuePairs([]);) 2025.07.13 02:38:49.955539 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:49.992617 [ 32979 ] {5739dc9a-be90-43b4-b834-9a8ac7ff910e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 544, line 545) (in query: SELECT extractKeyValuePairsWithEscaping([]);) 2025.07.13 02:38:49.998339 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.038187 [ 32979 ] {a8e95521-f901-4753-8494-1d8b1ff10929} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function extractTextFromHTML: In scope SELECT extractTextFromHTML([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 545, line 546) (in query: SELECT extractTextFromHTML([]);) 2025.07.13 02:38:50.045335 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function extractTextFromHTML: In scope SELECT extractTextFromHTML([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.078040 [ 32979 ] {eecb7447-01a5-4b84-bcaa-430b9898bbba} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 1, should be 2: In scope SELECT extractURLParameter([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 546, line 547) (in query: SELECT extractURLParameter([]);) 2025.07.13 02:38:50.083387 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 1, should be 2: In scope SELECT extractURLParameter([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:50.121372 [ 32979 ] {241afc00-04fb-4cd5-876e-bcd15c01cfcc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameterNames'. Expected: String, got: Array(Nothing): In scope SELECT extractURLParameterNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 547, line 548) (in query: SELECT extractURLParameterNames([]);) 2025.07.13 02:38:50.128575 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameterNames'. Expected: String, got: Array(Nothing): In scope SELECT extractURLParameterNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.155749 [ 32979 ] {25851168-61a9-41e1-9897-e8bbd5ba2117} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameters'. Expected: String, got: Array(Nothing): In scope SELECT extractURLParameters([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 548, line 549) (in query: SELECT extractURLParameters([]);) 2025.07.13 02:38:50.161006 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameters'. Expected: String, got: Array(Nothing): In scope SELECT extractURLParameters([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.197448 [ 32979 ] {83feb644-2fb5-44cf-b6a8-abb8f2288389} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function factorial: In scope SELECT factorial([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 549, line 550) (in query: SELECT factorial([]);) 2025.07.13 02:38:50.203073 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function factorial: In scope SELECT factorial([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.414744 [ 32979 ] {ba292704-eed1-41a4-95f5-3124d5712020} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file([]). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 552, line 553) (in query: SELECT file([]);) 2025.07.13 02:38:50.417619 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file([]). (NOT_IMPLEMENTED) 2025.07.13 02:38:50.466206 [ 32979 ] {f398667a-a17e-4133-a312-f049c7e59868} executeQuery: Code: 43. DB::Exception: Arguments of function filesystemAvailable should be String or FixedString: In scope SELECT filesystemAvailable([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 553, line 554) (in query: SELECT filesystemAvailable([]);) 2025.07.13 02:38:50.471843 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function filesystemAvailable should be String or FixedString: In scope SELECT filesystemAvailable([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.518523 [ 32979 ] {7e029bb0-8bbf-4d5f-a06e-481b76c4385d} executeQuery: Code: 43. DB::Exception: Arguments of function filesystemCapacity should be String or FixedString: In scope SELECT filesystemCapacity([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 554, line 555) (in query: SELECT filesystemCapacity([]);) 2025.07.13 02:38:50.524631 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function filesystemCapacity should be String or FixedString: In scope SELECT filesystemCapacity([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.611590 [ 32979 ] {109dde1a-7fbd-4d87-b4b3-084cbc7b31bc} executeQuery: Code: 43. DB::Exception: Arguments of function filesystemUnreserved should be String or FixedString: In scope SELECT filesystemUnreserved([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 555, line 556) (in query: SELECT filesystemUnreserved([]);) 2025.07.13 02:38:50.616824 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function filesystemUnreserved should be String or FixedString: In scope SELECT filesystemUnreserved([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.643985 [ 32979 ] {200a2104-23d3-43c6-9ece-ee6bb7023e41} executeQuery: Code: 43. DB::Exception: Argument for function 'finalizeAggregation' must have type AggregateFunction - state of aggregate function. Got 'Array(Nothing)' instead: In scope SELECT finalizeAggregation([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 556, line 557) (in query: SELECT finalizeAggregation([]);) 2025.07.13 02:38:50.649043 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function 'finalizeAggregation' must have type AggregateFunction - state of aggregate function. Got 'Array(Nothing)' instead: In scope SELECT finalizeAggregation([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.676859 [ 32979 ] {7e7ffc2d-7956-4e38-88a9-d0096fea1f50} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function firstLine: In scope SELECT firstLine([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 557, line 558) (in query: SELECT firstLine([]);) 2025.07.13 02:38:50.686011 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function firstLine: In scope SELECT firstLine([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.713396 [ 32979 ] {b6c2ecdb-794a-4ad1-8610-ab8eda74f66c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function firstSignificantSubdomain: In scope SELECT firstSignificantSubdomain([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 558, line 559) (in query: SELECT firstSignificantSubdomain([]);) 2025.07.13 02:38:50.719161 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function firstSignificantSubdomain: In scope SELECT firstSignificantSubdomain([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:50.749391 [ 32979 ] {127d79ce-6e88-441b-b913-9fbd80c4dfe8} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustom([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 559, line 560) (in query: SELECT firstSignificantSubdomainCustom([]);) 2025.07.13 02:38:50.754495 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustom([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:50.800513 [ 32979 ] {d25df512-b0f2-45a4-b354-eb3d1aa4812f} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomainCustomRFC([]);) 2025.07.13 02:38:50.805945 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:50.833333 [ 32979 ] {b0adfe27-bd92-43b7-ae14-72255642cc3d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function firstSignificantSubdomainRFC: In scope SELECT firstSignificantSubdomainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainRFC([]);) 2025.07.13 02:38:50.838089 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function firstSignificantSubdomainRFC: In scope SELECT firstSignificantSubdomainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.142486 [ 32979 ] {ddcfb5a8-cd7c-4c9e-93a3-ebe1f619f8a9} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 565, line 566) (in query: SELECT flameGraph([]);) 2025.07.13 02:38:51.144965 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.213288 [ 32979 ] {2d91eec8-1a19-4256-8cf5-202a3add0fee} executeQuery: Code: 43. DB::Exception: Argument for function 'flattenTuple' must be Named Tuple. Got 'Array(Nothing)': In scope SELECT flattenTuple([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 567, line 568) (in query: SELECT flattenTuple([]);) 2025.07.13 02:38:51.215492 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function 'flattenTuple' must be Named Tuple. Got 'Array(Nothing)': In scope SELECT flattenTuple([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.229549 [ 32979 ] {f121f471-b183-482e-aba9-3630f3731486} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'floor'. Expected: A number to round, got: Array(Nothing): In scope SELECT floor([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 568, line 569) (in query: SELECT floor([]);) 2025.07.13 02:38:51.232245 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'floor'. Expected: A number to round, got: Array(Nothing): In scope SELECT floor([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.252587 [ 32979 ] {87b8d094-3ebc-4078-b568-a415f9484583} executeQuery: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 1, should be at least 2: In scope SELECT format([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 569, line 570) (in query: SELECT format([]);) 2025.07.13 02:38:51.258511 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 1, should be at least 2: In scope SELECT format([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:51.284911 [ 32979 ] {41fafb66-0a0b-41d1-a160-fa586cfbaa48} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 570, line 571) (in query: SELECT formatDateTime([]);) 2025.07.13 02:38:51.288472 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:51.319751 [ 32979 ] {12cfa858-564e-4347-a26c-0b9f22ab821a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 571, line 572) (in query: SELECT formatDateTimeInJodaSyntax([]);) 2025.07.13 02:38:51.325681 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:51.359544 [ 32979 ] {6caff891-5555-437c-a5b5-1310276cab83} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuery'. Expected: String, got: Array(Nothing): In scope SELECT formatQuery([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 572, line 573) (in query: SELECT formatQuery([]);) 2025.07.13 02:38:51.365097 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuery'. Expected: String, got: Array(Nothing): In scope SELECT formatQuery([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.398486 [ 32979 ] {bee26403-f842-4361-86f2-739136c0047c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQueryOrNull'. Expected: String, got: Array(Nothing): In scope SELECT formatQueryOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 573, line 574) (in query: SELECT formatQueryOrNull([]);) 2025.07.13 02:38:51.405135 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQueryOrNull'. Expected: String, got: Array(Nothing): In scope SELECT formatQueryOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.437433 [ 32979 ] {6d69e00c-cf2d-47d0-9f73-e76bb706fa39} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLine'. Expected: String, got: Array(Nothing): In scope SELECT formatQuerySingleLine([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 574, line 575) (in query: SELECT formatQuerySingleLine([]);) 2025.07.13 02:38:51.443216 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLine'. Expected: String, got: Array(Nothing): In scope SELECT formatQuerySingleLine([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.474544 [ 32979 ] {7ac5a149-cfa0-44e4-86c5-b9ab23fbb6e7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLineOrNull'. Expected: String, got: Array(Nothing): In scope SELECT formatQuerySingleLineOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 575, line 576) (in query: SELECT formatQuerySingleLineOrNull([]);) 2025.07.13 02:38:51.480492 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLineOrNull'. Expected: String, got: Array(Nothing): In scope SELECT formatQuerySingleLineOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.509052 [ 32979 ] {fdd45595-bb88-4263-905b-6fa433aad2d8} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT formatReadableDecimalSize([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 576, line 577) (in query: SELECT formatReadableDecimalSize([]);) 2025.07.13 02:38:51.514556 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT formatReadableDecimalSize([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.567286 [ 32979 ] {6854877b-48a7-4d79-b5ac-d7cdd956a361} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT formatReadableQuantity([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 577, line 578) (in query: SELECT formatReadableQuantity([]);) 2025.07.13 02:38:51.574689 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT formatReadableQuantity([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.611046 [ 32979 ] {c7f00360-62be-4b14-b8a9-246e78a65f07} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT formatReadableSize([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 578, line 579) (in query: SELECT formatReadableSize([]);) 2025.07.13 02:38:51.615024 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) because it's not a numeric type: In scope SELECT formatReadableSize([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.736925 [ 32979 ] {d73083bc-03d8-467a-a3b3-112dff774369} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) as time delta: In scope SELECT formatReadableTimeDelta([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 579, line 580) (in query: SELECT formatReadableTimeDelta([]);) 2025.07.13 02:38:51.740614 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) as time delta: In scope SELECT formatReadableTimeDelta([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.797673 [ 32979 ] {5012e1cb-6b05-4328-9a9f-614e47282bd2} executeQuery: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 580, line 581) (in query: SELECT formatRow([]);) 2025.07.13 02:38:51.802300 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:51.834761 [ 32979 ] {03831949-02bf-45d5-89b6-c068c90861d3} executeQuery: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 581, line 582) (in query: SELECT formatRowNoNewline([]);) 2025.07.13 02:38:51.837694 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:51.860685 [ 32979 ] {7c3ea119-108e-4d2f-8d07-c3d51d8e3b40} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function fragment: In scope SELECT fragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 582, line 583) (in query: SELECT fragment([]);) 2025.07.13 02:38:51.863345 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function fragment: In scope SELECT fragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.891542 [ 32979 ] {16d5f513-7eb8-433b-80ee-d40dc4173fdc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'days' to function 'fromDaysSinceYearZero'. Expected: Integer, got: Array(Nothing): In scope SELECT fromDaysSinceYearZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 583, line 584) (in query: SELECT fromDaysSinceYearZero([]);) 2025.07.13 02:38:51.896819 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'days' to function 'fromDaysSinceYearZero'. Expected: Integer, got: Array(Nothing): In scope SELECT fromDaysSinceYearZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.919726 [ 32979 ] {18ec011f-5635-437e-9ca8-0a9e1516ea8c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'days' to function 'fromDaysSinceYearZero32'. Expected: Integer, got: Array(Nothing): In scope SELECT fromDaysSinceYearZero32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 584, line 585) (in query: SELECT fromDaysSinceYearZero32([]);) 2025.07.13 02:38:51.922950 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'days' to function 'fromDaysSinceYearZero32'. Expected: Integer, got: Array(Nothing): In scope SELECT fromDaysSinceYearZero32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:51.943034 [ 32979 ] {b3058946-ca45-4929-8f08-b55e86ee0878} executeQuery: Code: 43. DB::Exception: The argument of function fromModifiedJulianDay must be integral: In scope SELECT fromModifiedJulianDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 585, line 586) (in query: SELECT fromModifiedJulianDay([]);) 2025.07.13 02:38:51.949420 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function fromModifiedJulianDay must be integral: In scope SELECT fromModifiedJulianDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.005297 [ 32979 ] {7fedc27d-64cd-4cc9-bef5-bb84e004139b} executeQuery: Code: 43. DB::Exception: The argument of function fromModifiedJulianDayOrNull must be integral: In scope SELECT fromModifiedJulianDayOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 586, line 587) (in query: SELECT fromModifiedJulianDayOrNull([]);) 2025.07.13 02:38:52.008931 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function fromModifiedJulianDayOrNull must be integral: In scope SELECT fromModifiedJulianDayOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.028532 [ 32979 ] {fd41c809-9ed1-4dd8-8da6-a5bd24627aef} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT fromUTCTimestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 587, line 588) (in query: SELECT fromUTCTimestamp([]);) 2025.07.13 02:38:52.032341 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT fromUTCTimestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:52.050791 [ 32979 ] {2657ee98-6346-4ca7-9a7a-1ac82e7e1922} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 1. Should be integer: In scope SELECT fromUnixTimestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 588, line 589) (in query: SELECT fromUnixTimestamp([]);) 2025.07.13 02:38:52.118479 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 1. Should be integer: In scope SELECT fromUnixTimestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.208922 [ 32979 ] {d74e962c-ace0-45b6-96c0-7aa42174338d} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 589, line 590) (in query: SELECT fromUnixTimestamp64Micro([]);) 2025.07.13 02:38:52.216115 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.251672 [ 32979 ] {bc6ea4c4-cfa5-46b6-8ac1-599cb4a850e1} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 590, line 591) (in query: SELECT fromUnixTimestamp64Milli([]);) 2025.07.13 02:38:52.272379 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.320047 [ 32979 ] {396690de-bade-4c43-bc94-36331f71b737} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 591, line 592) (in query: SELECT fromUnixTimestamp64Nano([]);) 2025.07.13 02:38:52.323715 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.350618 [ 32979 ] {e50c8c82-66da-4cd4-a7a5-1ed132dd281f} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Second must be integer: In scope SELECT fromUnixTimestamp64Second([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 592, line 593) (in query: SELECT fromUnixTimestamp64Second([]);) 2025.07.13 02:38:52.354960 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Second must be integer: In scope SELECT fromUnixTimestamp64Second([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.427110 [ 32979 ] {629dfbc5-4478-4147-a48d-6cc2cadcdf85} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 1. Should be integer: In scope SELECT fromUnixTimestampInJodaSyntax([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 593, line 594) (in query: SELECT fromUnixTimestampInJodaSyntax([]);) 2025.07.13 02:38:52.431367 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 1. Should be integer: In scope SELECT fromUnixTimestampInJodaSyntax([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.540329 [ 32979 ] {65ec5742-faef-4aad-8324-6f54c43f43f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT from_utc_timestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 594, line 595) (in query: SELECT from_utc_timestamp([]);) 2025.07.13 02:38:52.545257 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT from_utc_timestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:52.596460 [ 32979 ] {b610f473-efd3-43fe-88e7-63cc41a6fb54} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT fullHostName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 595, line 596) (in query: SELECT fullHostName([]);) 2025.07.13 02:38:52.602689 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT fullHostName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:52.634666 [ 32979 ] {aefce779-7618-48f6-a237-b4631b67d306} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 1, should be 2: In scope SELECT fuzzBits([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 596, line 597) (in query: SELECT fuzzBits([]);) 2025.07.13 02:38:52.640584 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 1, should be 2: In scope SELECT fuzzBits([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:52.857290 [ 32979 ] {c748fffe-4ad9-428e-9da7-fe399e0cb4f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 1, should be 2: In scope SELECT gcd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 598, line 599) (in query: SELECT gcd([]);) 2025.07.13 02:38:52.869296 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 1, should be 2: In scope SELECT gcd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:52.896175 [ 32979 ] {c3cf30d9-9c22-415d-ae23-bf2e8d5af47e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 599, line 600) (in query: SELECT generateRandomStructure([]);) 2025.07.13 02:38:52.900379 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:52.981036 [ 32979 ] {6c6e8737-7e02-4815-8167-1ddc885c81b4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: Array(Nothing): In scope SELECT generateSerialID([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 600, line 601) (in query: SELECT generateSerialID([]);) 2025.07.13 02:38:52.984801 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: Array(Nothing): In scope SELECT generateSerialID([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:53.346686 [ 32979 ] {468da48c-1b4c-4c89-be6c-c781a4c5ce63} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 1, should be 4: In scope SELECT geoDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 605, line 606) (in query: SELECT geoDistance([]);) 2025.07.13 02:38:53.354005 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 1, should be 4: In scope SELECT geoDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:53.411868 [ 32979 ] {100f621f-45ab-4d01-8637-1eeeaf9b153c} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 1, should be 3: In scope SELECT geoToH3([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 606, line 607) (in query: SELECT geoToH3([]);) 2025.07.13 02:38:53.416587 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 1, should be 3: In scope SELECT geoToH3([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:53.550084 [ 32979 ] {3fe42ec2-4733-4b81-b6a7-1f9d7cd997a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 1, should be 2: In scope SELECT geoToS2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 607, line 608) (in query: SELECT geoToS2([]);) 2025.07.13 02:38:53.554409 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 1, should be 2: In scope SELECT geoToS2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:53.587137 [ 32979 ] {1e983650-5136-4125-afd1-9bdc24d2aa82} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'encoded' to function 'geohashDecode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT geohashDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 608, line 609) (in query: SELECT geohashDecode([]);) 2025.07.13 02:38:53.592325 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'encoded' to function 'geohashDecode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT geohashDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:53.628639 [ 32979 ] {81e02785-496a-427c-83b6-7528bb149804} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT geohashEncode([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 609, line 610) (in query: SELECT geohashEncode([]);) 2025.07.13 02:38:53.635412 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT geohashEncode([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:53.673601 [ 32979 ] {e3980768-9fed-4140-a30a-8c45b96a514b} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 1, should be 5: In scope SELECT geohashesInBox([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 610, line 611) (in query: SELECT geohashesInBox([]);) 2025.07.13 02:38:53.679956 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 1, should be 5: In scope SELECT geohashesInBox([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:53.717300 [ 32979 ] {01a02acb-d9f6-42db-8e87-c68335f3dc6d} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 611, line 612) (in query: SELECT getClientHTTPHeader([]);) 2025.07.13 02:38:53.724708 [ 32979 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.07.13 02:38:53.771475 [ 32979 ] {d39acdac-a646-4351-80dd-27f6a87a115b} executeQuery: Code: 43. DB::Exception: The argument of function getMacro must have String type: In scope SELECT getMacro([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 612, line 613) (in query: SELECT getMacro([]);) 2025.07.13 02:38:53.776527 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getMacro must have String type: In scope SELECT getMacro([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:53.853299 [ 32979 ] {366961d7-0015-49ed-8c3a-ba3cedf098e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function getMaxTableNameLengthForDatabase, expected String or FixedString: In scope SELECT getMaxTableNameLengthForDatabase([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 613, line 614) (in query: SELECT getMaxTableNameLengthForDatabase([]);) 2025.07.13 02:38:53.858854 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function getMaxTableNameLengthForDatabase, expected String or FixedString: In scope SELECT getMaxTableNameLengthForDatabase([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:53.904577 [ 32979 ] {bcdc45ca-3bae-4e89-9e23-59d27a33a772} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 1, should be 0: In scope SELECT getOSKernelVersion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 614, line 615) (in query: SELECT getOSKernelVersion([]);) 2025.07.13 02:38:53.911893 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 1, should be 0: In scope SELECT getOSKernelVersion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.032210 [ 32979 ] {52a7a1c3-a4d3-425b-aa3a-eae542f615bf} executeQuery: Code: 43. DB::Exception: The argument of function getServerPort should be a constant string with the name of a setting: In scope SELECT getServerPort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 615, line 616) (in query: SELECT getServerPort([]);) 2025.07.13 02:38:54.043803 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getServerPort should be a constant string with the name of a setting: In scope SELECT getServerPort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:54.080376 [ 32979 ] {350a7e11-d662-4e46-8b33-fce193087b11} executeQuery: Code: 43. DB::Exception: The argument of function getSetting should be a constant string with the name of a setting: In scope SELECT getSetting([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 616, line 617) (in query: SELECT getSetting([]);) 2025.07.13 02:38:54.087708 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getSetting should be a constant string with the name of a setting: In scope SELECT getSetting([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:54.130533 [ 32979 ] {ddb01886-d95d-4e9c-85c2-cca6962299b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 617, line 618) (in query: SELECT getSettingOrDefault([]);) 2025.07.13 02:38:54.139322 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.167324 [ 32979 ] {ff2d36ab-4ba7-4e04-9c52-27e6277904d6} executeQuery: Code: 43. DB::Exception: The argument for function getSizeOfEnumType must be Enum: In scope SELECT getSizeOfEnumType([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 618, line 619) (in query: SELECT getSizeOfEnumType([]);) 2025.07.13 02:38:54.171479 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument for function getSizeOfEnumType must be Enum: In scope SELECT getSizeOfEnumType([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:54.206191 [ 32979 ] {58cbb7e0-0b48-4a4d-920d-dd90f26fd57e} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 1, should be 2: In scope SELECT getSubcolumn([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 619, line 620) (in query: SELECT getSubcolumn([]);) 2025.07.13 02:38:54.212541 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 1, should be 2: In scope SELECT getSubcolumn([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.338934 [ 32979 ] {440b7f38-339a-43db-bb28-ec6af34dfa7c} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 621, line 622) (in query: SELECT globalIn([]);) 2025.07.13 02:38:54.345634 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.440297 [ 32979 ] {3cd83ed9-d837-4310-8866-5165a02df3c9} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 622, line 623) (in query: SELECT globalInIgnoreSet([]);) 2025.07.13 02:38:54.443331 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.465963 [ 32979 ] {9b1794d2-832f-411d-aa0b-1633390fa27e} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 623, line 624) (in query: SELECT globalNotIn([]);) 2025.07.13 02:38:54.468815 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.594245 [ 32979 ] {9c3e7e32-05c2-4f6c-9b07-cdca827268b5} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 624, line 625) (in query: SELECT globalNotInIgnoreSet([]);) 2025.07.13 02:38:54.597435 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.615491 [ 32979 ] {0c16857a-782a-4779-bd2b-69361eb29599} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 625, line 626) (in query: SELECT globalNotNullIn([]);) 2025.07.13 02:38:54.619454 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.652997 [ 32979 ] {8fbe9300-94fd-4e16-87f9-994806a9c1ce} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 626, line 627) (in query: SELECT globalNotNullInIgnoreSet([]);) 2025.07.13 02:38:54.658504 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.686856 [ 32979 ] {4d9d0a55-bb02-4c45-b1fc-61d990979f95} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 627, line 628) (in query: SELECT globalNullIn([]);) 2025.07.13 02:38:54.691602 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.721683 [ 32979 ] {823adb0c-f8ce-4a13-b5fc-340fcb43f0b0} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 628, line 629) (in query: SELECT globalNullInIgnoreSet([]);) 2025.07.13 02:38:54.728144 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.767534 [ 32979 ] {02fa83d4-c162-4ddf-8ec1-a55a6a59a504} executeQuery: Code: 36. DB::Exception: Argument of function globalVariable must be constant string: In scope SELECT globalVariable([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 629, line 630) (in query: SELECT globalVariable([]);) 2025.07.13 02:38:54.772850 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Argument of function globalVariable must be constant string: In scope SELECT globalVariable([]). (BAD_ARGUMENTS) 2025.07.13 02:38:54.800699 [ 32979 ] {2a7155bb-fc12-46c6-9d77-5206b361f216} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 1, should be 4: In scope SELECT greatCircleAngle([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 630, line 631) (in query: SELECT greatCircleAngle([]);) 2025.07.13 02:38:54.806872 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 1, should be 4: In scope SELECT greatCircleAngle([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.858676 [ 32979 ] {4d1f1569-4182-42d2-a75f-3cd6eedc2b6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 1, should be 4: In scope SELECT greatCircleDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 631, line 632) (in query: SELECT greatCircleDistance([]);) 2025.07.13 02:38:54.864628 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 1, should be 4: In scope SELECT greatCircleDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.961048 [ 32979 ] {3160286b-cc68-4936-9d28-fb8ffd5ffe49} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 1, should be 2: In scope SELECT greater([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 632, line 633) (in query: SELECT greater([]);) 2025.07.13 02:38:54.964236 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 1, should be 2: In scope SELECT greater([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:54.987562 [ 32979 ] {e7d83460-146e-463e-9e09-c5c2b9b0f60d} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 1, should be 2: In scope SELECT greaterOrEquals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 633, line 634) (in query: SELECT greaterOrEquals([]);) 2025.07.13 02:38:54.995210 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 1, should be 2: In scope SELECT greaterOrEquals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:55.203253 [ 32979 ] {67a02430-6aee-4f30-80d9-e562531bce66} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 636, line 637) (in query: SELECT groupArrayInsertAt([]);) 2025.07.13 02:38:55.208040 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:55.382476 [ 32979 ] {e46d4cd2-b5a5-4d56-af79-c745d2fe8db7} executeQuery: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 638, line 639) (in query: SELECT groupArrayLast([]);) 2025.07.13 02:38:55.385830 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS) 2025.07.13 02:38:55.419070 [ 32979 ] {c4696d6c-9423-4209-bf7f-cd8fdfe746d0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupArrayMovingAvg. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 639, line 640) (in query: SELECT groupArrayMovingAvg([]);) 2025.07.13 02:38:55.425209 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupArrayMovingAvg. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.460321 [ 32979 ] {b3ee6790-e397-4904-b7bb-7c09792ea656} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupArrayMovingSum. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 640, line 641) (in query: SELECT groupArrayMovingSum([]);) 2025.07.13 02:38:55.466010 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupArrayMovingSum. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.584797 [ 32979 ] {42ff8897-2d0c-40f7-a30d-3c278025e202} executeQuery: Code: 42. DB::Exception: Incorrect number of parameters for aggregate function groupArraySample, should be 1 or 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 641, line 642) (in query: SELECT groupArraySample([]);) 2025.07.13 02:38:55.590149 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of parameters for aggregate function groupArraySample, should be 1 or 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:55.636911 [ 32979 ] {d848cdf1-f32c-4855-9c34-80b2689a00a6} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should have limit argument. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 642, line 643) (in query: SELECT groupArraySorted([]);) 2025.07.13 02:38:55.650394 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should have limit argument. (BAD_ARGUMENTS) 2025.07.13 02:38:55.686712 [ 32979 ] {8c0eddc1-bc51-4d29-9a38-c3be1338522b} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitAnd is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 643, line 644) (in query: SELECT groupBitAnd([]);) 2025.07.13 02:38:55.693139 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitAnd is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.728948 [ 32979 ] {798c7407-9004-470e-a49c-b6c684f8ed24} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitOr is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 644, line 645) (in query: SELECT groupBitOr([]);) 2025.07.13 02:38:55.733540 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitOr is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.760247 [ 32979 ] {21e14380-86b5-4b9e-baa3-24ea3d2a0f7a} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitXor is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 645, line 646) (in query: SELECT groupBitXor([]);) 2025.07.13 02:38:55.766065 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitXor is illegal, because it cannot be used in bitwise operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.801279 [ 32979 ] {e371706b-dca7-4893-80cd-2871850cd5cb} executeQuery: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitmap is illegal, because it cannot be used in Bitmap operations. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 646, line 647) (in query: SELECT groupBitmap([]);) 2025.07.13 02:38:55.805516 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The type Array(Nothing) of argument for aggregate function groupBitmap is illegal, because it cannot be used in Bitmap operations. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.823884 [ 32979 ] {dcf59815-a427-4641-9a14-d711c5d060d2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 647, line 648) (in query: SELECT groupBitmapAnd([]);) 2025.07.13 02:38:55.829667 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.847828 [ 32979 ] {6b50fd68-dd6c-4fd9-b339-21a950984a6b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 648, line 649) (in query: SELECT groupBitmapOr([]);) 2025.07.13 02:38:55.850844 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:55.889923 [ 32979 ] {64e89995-8110-4f47-828e-42b0709b6b75} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 649, line 650) (in query: SELECT groupBitmapXor([]);) 2025.07.13 02:38:55.896516 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.303329 [ 32979 ] {9625142f-a2c6-4108-806c-90f521e4121d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3CellAreaM2. Must be UInt64: In scope SELECT h3CellAreaM2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 653, line 654) (in query: SELECT h3CellAreaM2([]);) 2025.07.13 02:38:56.306613 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3CellAreaM2. Must be UInt64: In scope SELECT h3CellAreaM2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.324187 [ 32979 ] {c3ca1aae-6327-4b41-b462-0ef27cfd20ec} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3CellAreaRads2. Must be UInt64: In scope SELECT h3CellAreaRads2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 654, line 655) (in query: SELECT h3CellAreaRads2([]);) 2025.07.13 02:38:56.327224 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3CellAreaRads2. Must be UInt64: In scope SELECT h3CellAreaRads2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.345024 [ 32979 ] {11693dc0-5edb-46c9-8cf1-5052eaa6d6d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 1, should be 2: In scope SELECT h3Distance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 655, line 656) (in query: SELECT h3Distance([]);) 2025.07.13 02:38:56.348869 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 1, should be 2: In scope SELECT h3Distance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:56.368157 [ 32979 ] {50d95cc6-ac13-44bb-b30b-d94084a42ec2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3EdgeAngle. Must be UInt8: In scope SELECT h3EdgeAngle([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 656, line 657) (in query: SELECT h3EdgeAngle([]);) 2025.07.13 02:38:56.371662 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3EdgeAngle. Must be UInt8: In scope SELECT h3EdgeAngle([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.475186 [ 32979 ] {efd16bcc-fae0-4d33-aae5-1fd98eb0d857} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3EdgeLengthKm. Must be UInt8: In scope SELECT h3EdgeLengthKm([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 657, line 658) (in query: SELECT h3EdgeLengthKm([]);) 2025.07.13 02:38:56.480934 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3EdgeLengthKm. Must be UInt8: In scope SELECT h3EdgeLengthKm([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.512751 [ 32979 ] {77910772-0583-498b-877b-f415b6e609d7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3EdgeLengthM. Must be UInt8: In scope SELECT h3EdgeLengthM([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 658, line 659) (in query: SELECT h3EdgeLengthM([]);) 2025.07.13 02:38:56.517138 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3EdgeLengthM. Must be UInt8: In scope SELECT h3EdgeLengthM([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.534812 [ 32979 ] {89f3d832-d207-4dd2-afba-413cce56225f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ExactEdgeLengthKm. Must be UInt64: In scope SELECT h3ExactEdgeLengthKm([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 659, line 660) (in query: SELECT h3ExactEdgeLengthKm([]);) 2025.07.13 02:38:56.537873 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ExactEdgeLengthKm. Must be UInt64: In scope SELECT h3ExactEdgeLengthKm([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.558466 [ 32979 ] {50b57c31-4a6b-4625-b750-db67fe47ca1c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ExactEdgeLengthM. Must be UInt64: In scope SELECT h3ExactEdgeLengthM([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 660, line 661) (in query: SELECT h3ExactEdgeLengthM([]);) 2025.07.13 02:38:56.566077 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ExactEdgeLengthM. Must be UInt64: In scope SELECT h3ExactEdgeLengthM([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.650033 [ 32979 ] {7c489cc1-dafb-43ff-b8c6-d6ee95159b1d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ExactEdgeLengthRads. Must be UInt64: In scope SELECT h3ExactEdgeLengthRads([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthRads([]);) 2025.07.13 02:38:56.656935 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ExactEdgeLengthRads. Must be UInt64: In scope SELECT h3ExactEdgeLengthRads([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.702929 [ 32979 ] {a4bb6eb5-294e-49b8-924c-c0ce787890dd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetBaseCell. Must be UInt64: In scope SELECT h3GetBaseCell([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 662, line 663) (in query: SELECT h3GetBaseCell([]);) 2025.07.13 02:38:56.726500 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetBaseCell. Must be UInt64: In scope SELECT h3GetBaseCell([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.792315 [ 32979 ] {fea6f769-e630-4878-a4a2-85595d567222} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetDestinationIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 663, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge([]);) 2025.07.13 02:38:56.795611 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetDestinationIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.813020 [ 32979 ] {daea2867-8b09-405e-b76f-554bf753f73f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetFaces. Must be UInt64: In scope SELECT h3GetFaces([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 664, line 665) (in query: SELECT h3GetFaces([]);) 2025.07.13 02:38:56.815853 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetFaces. Must be UInt64: In scope SELECT h3GetFaces([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.832278 [ 32979 ] {a3ef3f1e-99fe-4d70-bc98-95bd33790590} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetIndexesFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetIndexesFromUnidirectionalEdge([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 665, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge([]);) 2025.07.13 02:38:56.835196 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetIndexesFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetIndexesFromUnidirectionalEdge([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.865119 [ 32979 ] {6269d6a5-fcac-4aad-91ff-022af9f3c4ce} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetOriginIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 666, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge([]);) 2025.07.13 02:38:56.868486 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetOriginIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.904451 [ 32979 ] {1f5411a3-46ef-428e-90a2-d7ac366112f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetPentagonIndexes. Must be UInt8: In scope SELECT h3GetPentagonIndexes([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 667, line 668) (in query: SELECT h3GetPentagonIndexes([]);) 2025.07.13 02:38:56.908193 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetPentagonIndexes. Must be UInt8: In scope SELECT h3GetPentagonIndexes([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:56.983145 [ 32979 ] {94fb0c27-e58e-4930-9b8b-f302a7c63c42} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 1, should be 0: In scope SELECT h3GetRes0Indexes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 668, line 669) (in query: SELECT h3GetRes0Indexes([]);) 2025.07.13 02:38:56.987416 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 1, should be 0: In scope SELECT h3GetRes0Indexes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.014327 [ 32979 ] {63b083cf-5cd0-4e66-bc05-59b658fc33d1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetResolution. Must be UInt64: In scope SELECT h3GetResolution([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 669, line 670) (in query: SELECT h3GetResolution([]);) 2025.07.13 02:38:57.038826 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetResolution. Must be UInt64: In scope SELECT h3GetResolution([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.061265 [ 32979 ] {c37fee37-b5bb-498e-8adf-13007819ea68} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 1, should be 2: In scope SELECT h3GetUnidirectionalEdge([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 670, line 671) (in query: SELECT h3GetUnidirectionalEdge([]);) 2025.07.13 02:38:57.065058 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 1, should be 2: In scope SELECT h3GetUnidirectionalEdge([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.160997 [ 32979 ] {3045e96e-9c3e-4cfa-99f8-4752b72db5a1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetUnidirectionalEdgeBoundary. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgeBoundary([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 671, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary([]);) 2025.07.13 02:38:57.164894 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetUnidirectionalEdgeBoundary. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgeBoundary([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.188550 [ 32979 ] {16097404-3e54-4fc3-8c23-d16dcaf7c44c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetUnidirectionalEdgesFromHexagon. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon([]);) 2025.07.13 02:38:57.197031 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetUnidirectionalEdgesFromHexagon. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.214388 [ 32979 ] {ddd4e525-0598-40e2-b684-4cabca2aaa1a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3HexAreaKm2. Must be UInt8: In scope SELECT h3HexAreaKm2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 673, line 674) (in query: SELECT h3HexAreaKm2([]);) 2025.07.13 02:38:57.217650 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3HexAreaKm2. Must be UInt8: In scope SELECT h3HexAreaKm2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.270420 [ 32979 ] {b700d258-3a2b-4ebc-b0e4-36142174c28e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3HexAreaM2. Must be UInt8: In scope SELECT h3HexAreaM2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 674, line 675) (in query: SELECT h3HexAreaM2([]);) 2025.07.13 02:38:57.275561 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3HexAreaM2. Must be UInt8: In scope SELECT h3HexAreaM2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.319093 [ 32979 ] {fc173346-a680-4ecb-8a6b-bc5f2220cd58} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 1, should be 2: In scope SELECT h3HexRing([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 675, line 676) (in query: SELECT h3HexRing([]);) 2025.07.13 02:38:57.367208 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 1, should be 2: In scope SELECT h3HexRing([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.397842 [ 32979 ] {3f858cee-edae-4d45-b756-6260f2741a81} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 1, should be 2: In scope SELECT h3IndexesAreNeighbors([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 676, line 677) (in query: SELECT h3IndexesAreNeighbors([]);) 2025.07.13 02:38:57.403289 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 1, should be 2: In scope SELECT h3IndexesAreNeighbors([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.430904 [ 32979 ] {4aef948e-dd5e-45aa-8d83-55d2a1db2224} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IsPentagon. Must be UInt64: In scope SELECT h3IsPentagon([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 677, line 678) (in query: SELECT h3IsPentagon([]);) 2025.07.13 02:38:57.441902 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IsPentagon. Must be UInt64: In scope SELECT h3IsPentagon([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.475384 [ 32979 ] {09eeb417-0511-482d-9116-b508a82d7256} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IsResClassIII. Must be UInt64: In scope SELECT h3IsResClassIII([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 678, line 679) (in query: SELECT h3IsResClassIII([]);) 2025.07.13 02:38:57.481653 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IsResClassIII. Must be UInt64: In scope SELECT h3IsResClassIII([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.512289 [ 32979 ] {94ead558-dea5-4dfe-b283-56b312cb451d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IsValid. Must be UInt64: In scope SELECT h3IsValid([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 679, line 680) (in query: SELECT h3IsValid([]);) 2025.07.13 02:38:57.517513 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IsValid. Must be UInt64: In scope SELECT h3IsValid([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.535471 [ 32979 ] {2f757abf-7bf6-4eb3-8850-66637086a9b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 1, should be 2: In scope SELECT h3Line([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 680, line 681) (in query: SELECT h3Line([]);) 2025.07.13 02:38:57.538880 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 1, should be 2: In scope SELECT h3Line([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.556519 [ 32979 ] {a228f17a-9762-4d0d-b1f5-b59624e28b06} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3NumHexagons. Must be UInt8: In scope SELECT h3NumHexagons([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 681, line 682) (in query: SELECT h3NumHexagons([]);) 2025.07.13 02:38:57.559590 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3NumHexagons. Must be UInt8: In scope SELECT h3NumHexagons([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.586426 [ 32979 ] {e2293da8-df77-469e-b89c-d2b907b00ed4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 1, should be 4: In scope SELECT h3PointDistKm([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 682, line 683) (in query: SELECT h3PointDistKm([]);) 2025.07.13 02:38:57.590169 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 1, should be 4: In scope SELECT h3PointDistKm([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.614345 [ 32979 ] {02067992-6029-46b8-b18b-2bdb130dc2d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 1, should be 4: In scope SELECT h3PointDistM([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 683, line 684) (in query: SELECT h3PointDistM([]);) 2025.07.13 02:38:57.618967 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 1, should be 4: In scope SELECT h3PointDistM([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.644644 [ 32979 ] {da322f2f-4ac4-4127-adf7-e4ba2797a2b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 1, should be 4: In scope SELECT h3PointDistRads([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 684, line 685) (in query: SELECT h3PointDistRads([]);) 2025.07.13 02:38:57.649418 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 1, should be 4: In scope SELECT h3PointDistRads([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.767581 [ 32979 ] {582646e4-ff8f-44a7-9fb6-fc99461d9a30} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 1, should be 2: In scope SELECT h3ToCenterChild([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 685, line 686) (in query: SELECT h3ToCenterChild([]);) 2025.07.13 02:38:57.772526 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 1, should be 2: In scope SELECT h3ToCenterChild([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.875461 [ 32979 ] {c7afeb03-763e-4338-a657-c80f3674bce0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 1, should be 2: In scope SELECT h3ToChildren([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 686, line 687) (in query: SELECT h3ToChildren([]);) 2025.07.13 02:38:57.882553 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 1, should be 2: In scope SELECT h3ToChildren([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:57.910616 [ 32979 ] {22d7fa78-ecab-4f52-a842-23c4ccfb9838} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToGeo. Must be UInt64: In scope SELECT h3ToGeo([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 687, line 688) (in query: SELECT h3ToGeo([]);) 2025.07.13 02:38:57.915553 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToGeo. Must be UInt64: In scope SELECT h3ToGeo([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:57.976364 [ 32979 ] {00004e89-405b-4290-a908-d8a58ced3e5e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToGeoBoundary. Must be UInt64: In scope SELECT h3ToGeoBoundary([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 688, line 689) (in query: SELECT h3ToGeoBoundary([]);) 2025.07.13 02:38:57.994785 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToGeoBoundary. Must be UInt64: In scope SELECT h3ToGeoBoundary([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:58.043159 [ 32979 ] {d28b5c2f-d722-4d45-9237-701a9bdbc638} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 1, should be 2: In scope SELECT h3ToParent([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 689, line 690) (in query: SELECT h3ToParent([]);) 2025.07.13 02:38:58.049116 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 1, should be 2: In scope SELECT h3ToParent([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.070798 [ 32979 ] {03b83518-ca95-4af1-98e4-f7d333d93d15} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToString. Must be UInt64: In scope SELECT h3ToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 690, line 691) (in query: SELECT h3ToString([]);) 2025.07.13 02:38:58.076598 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToString. Must be UInt64: In scope SELECT h3ToString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:58.098221 [ 32979 ] {54539a69-fc88-4124-8d8e-784caef02adc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3UnidirectionalEdgeIsValid. Must be UInt64: In scope SELECT h3UnidirectionalEdgeIsValid([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 691, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid([]);) 2025.07.13 02:38:58.104867 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3UnidirectionalEdgeIsValid. Must be UInt64: In scope SELECT h3UnidirectionalEdgeIsValid([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:58.126509 [ 32979 ] {e2b9f51e-4c90-48e8-a7f1-81d8e31eebc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 1, should be 2: In scope SELECT h3kRing([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 692, line 693) (in query: SELECT h3kRing([]);) 2025.07.13 02:38:58.130404 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 1, should be 2: In scope SELECT h3kRing([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.276595 [ 32979 ] {539f4991-a496-4765-88d8-e987867b4aec} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 1, should be 2: In scope SELECT has([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 694, line 695) (in query: SELECT has([]);) 2025.07.13 02:38:58.281900 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 1, should be 2: In scope SELECT has([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.314189 [ 32979 ] {e4d87790-a954-43c2-b8c3-98af0af3fe93} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 1, should be 2: In scope SELECT hasAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 695, line 696) (in query: SELECT hasAll([]);) 2025.07.13 02:38:58.318806 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 1, should be 2: In scope SELECT hasAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.346056 [ 32979 ] {f09eb9cc-db13-4661-a985-8faa99553a85} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 1, should be 2: In scope SELECT hasAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 696, line 697) (in query: SELECT hasAny([]);) 2025.07.13 02:38:58.351630 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 1, should be 2: In scope SELECT hasAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.387059 [ 32979 ] {85d13beb-8982-4805-ad0f-e095e9a92493} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 697, line 698) (in query: SELECT hasColumnInTable([]);) 2025.07.13 02:38:58.392515 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.437606 [ 32979 ] {e4e609fa-7586-49bd-912a-df2ec3e29bca} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 1, should be 2: In scope SELECT hasSubsequence([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 698, line 699) (in query: SELECT hasSubsequence([]);) 2025.07.13 02:38:58.443489 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 1, should be 2: In scope SELECT hasSubsequence([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.485236 [ 32979 ] {f410489f-a0ff-4336-9e91-fc5afcede26a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 699, line 700) (in query: SELECT hasSubsequenceCaseInsensitive([]);) 2025.07.13 02:38:58.490431 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.543748 [ 32979 ] {c7ee4d69-1b11-4e2c-bbf8-dc63f96162c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 700, line 701) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8([]);) 2025.07.13 02:38:58.558887 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.612284 [ 32979 ] {fd786d43-d8f8-48a3-a92d-70cfddf453ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 701, line 702) (in query: SELECT hasSubsequenceUTF8([]);) 2025.07.13 02:38:58.620922 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.652109 [ 32979 ] {a6b7c98f-e814-45df-bf62-d8cbb109676a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 1, should be 2: In scope SELECT hasSubstr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 702, line 703) (in query: SELECT hasSubstr([]);) 2025.07.13 02:38:58.655811 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 1, should be 2: In scope SELECT hasSubstr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.677409 [ 32979 ] {992f1984-a4c5-4dd2-a040-63f6171fcc9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 1, should be 0: In scope SELECT hasThreadFuzzer([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 703, line 704) (in query: SELECT hasThreadFuzzer([]);) 2025.07.13 02:38:58.681205 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 1, should be 0: In scope SELECT hasThreadFuzzer([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.700109 [ 32979 ] {36a914a4-0096-4672-b0a7-3974c932504e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 1, should be 2: In scope SELECT hasToken([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 704, line 705) (in query: SELECT hasToken([]);) 2025.07.13 02:38:58.703956 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 1, should be 2: In scope SELECT hasToken([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.727942 [ 32979 ] {e4ebcada-6e0b-4c03-b298-381131ae28f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 705, line 706) (in query: SELECT hasTokenCaseInsensitive([]);) 2025.07.13 02:38:58.734273 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.763570 [ 32979 ] {58fa3946-f5c0-4170-831d-7dfd8c45c6d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 706, line 707) (in query: SELECT hasTokenCaseInsensitiveOrNull([]);) 2025.07.13 02:38:58.770296 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.792538 [ 32979 ] {bf992643-7b6a-48de-8879-0c68241592cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 707, line 708) (in query: SELECT hasTokenOrNull([]);) 2025.07.13 02:38:58.795396 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.821180 [ 32979 ] {21c53f0c-118f-4053-ae07-a7de138aa6e7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hex: In scope SELECT hex([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 708, line 709) (in query: SELECT hex([]);) 2025.07.13 02:38:58.824585 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hex: In scope SELECT hex([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:58.860151 [ 32979 ] {b5adc7ca-6212-4526-bd32-9d7130f55dab} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 1, should be 2: In scope SELECT hilbertDecode([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 709, line 710) (in query: SELECT hilbertDecode([]);) 2025.07.13 02:38:58.865436 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 1, should be 2: In scope SELECT hilbertDecode([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:58.902042 [ 32979 ] {33fa6c70-eda7-4dd3-bd99-ca7f275b68dc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 710, line 711) (in query: SELECT hilbertEncode([]);) 2025.07.13 02:38:58.906713 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:59.099288 [ 32979 ] {223872bf-b6d1-44d1-a1ac-378d7939806e} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 711, line 712) (in query: SELECT histogram([]);) 2025.07.13 02:38:59.104777 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.186608 [ 32979 ] {31b21b86-e43a-49a4-8622-7d69c4daabde} executeQuery: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 1, should be 3 or 4: In scope SELECT hop([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 713, line 714) (in query: SELECT hop([]);) 2025.07.13 02:38:59.224428 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 1, should be 3 or 4: In scope SELECT hop([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.271210 [ 32979 ] {454caf27-5ab8-4ecb-a987-b979ecbd7c45} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function hopEnd should be DateTime, Tuple or UInt32: In scope SELECT hopEnd([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 714, line 715) (in query: SELECT hopEnd([]);) 2025.07.13 02:38:59.285953 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function hopEnd should be DateTime, Tuple or UInt32: In scope SELECT hopEnd([]). (ILLEGAL_COLUMN) 2025.07.13 02:38:59.313723 [ 32979 ] {78bf1a73-a92a-48f4-a711-50b7ba8e99d3} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function hopStart should be DateTime, Tuple or UInt32: In scope SELECT hopStart([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 715, line 716) (in query: SELECT hopStart([]);) 2025.07.13 02:38:59.327245 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function hopStart should be DateTime, Tuple or UInt32: In scope SELECT hopStart([]). (ILLEGAL_COLUMN) 2025.07.13 02:38:59.355066 [ 32979 ] {d6b4bd94-aa7e-43a9-a91b-b661ff478049} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 716, line 717) (in query: SELECT hostName([]);) 2025.07.13 02:38:59.364605 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostName([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.435872 [ 32979 ] {b629df09-6034-4e86-bc3f-66b3b996b9b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostname([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 717, line 718) (in query: SELECT hostname([]);) 2025.07.13 02:38:59.440561 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostname([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.491478 [ 32979 ] {181776cf-74d6-4538-ade9-c9087d699779} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 1, should be 2: In scope SELECT hypot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 718, line 719) (in query: SELECT hypot([]);) 2025.07.13 02:38:59.494914 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 1, should be 2: In scope SELECT hypot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.524080 [ 32979 ] {20c60b07-3023-4057-ad66-99d76ba53618} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 1, should be 2: In scope SELECT icebergBucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 719, line 720) (in query: SELECT icebergBucket([]);) 2025.07.13 02:38:59.527580 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 1, should be 2: In scope SELECT icebergBucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.562694 [ 32979 ] {495121ae-0f42-4099-bc7b-ec74e1e1801d} executeQuery: Code: 43. DB::Exception: Unsupported data type `Array(Nothing)` for icebergHash: In scope SELECT icebergHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 720, line 721) (in query: SELECT icebergHash([]);) 2025.07.13 02:38:59.567849 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Unsupported data type `Array(Nothing)` for icebergHash: In scope SELECT icebergHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:59.602781 [ 32979 ] {c1a0433a-939c-462d-b17b-c92161df6593} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 1, should be 2: In scope SELECT icebergTruncate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 721, line 722) (in query: SELECT icebergTruncate([]);) 2025.07.13 02:38:59.609625 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 1, should be 2: In scope SELECT icebergTruncate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.829464 [ 32979 ] {74dfd746-2f1e-4501-9154-c03055326836} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function idnaDecode: In scope SELECT idnaDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 723, line 724) (in query: SELECT idnaDecode([]);) 2025.07.13 02:38:59.834413 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function idnaDecode: In scope SELECT idnaDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:59.863034 [ 32979 ] {286591b7-80d8-437f-8fab-c3d57e4f53d0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function idnaEncode: In scope SELECT idnaEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 724, line 725) (in query: SELECT idnaEncode([]);) 2025.07.13 02:38:59.869005 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function idnaEncode: In scope SELECT idnaEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:38:59.899036 [ 32979 ] {59a83013-1730-4776-a866-ddd38de711d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 725, line 726) (in query: SELECT if([]);) 2025.07.13 02:38:59.903048 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.939653 [ 32979 ] {dc128bea-1493-4bbe-8adc-24fb38dca6f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 1, should be 2: In scope SELECT ifNotFinite([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 726, line 727) (in query: SELECT ifNotFinite([]);) 2025.07.13 02:38:59.943027 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 1, should be 2: In scope SELECT ifNotFinite([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:38:59.960700 [ 32979 ] {8fd45822-c695-4e79-b08a-9f60331a236a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 1, should be 2: In scope SELECT ifNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 727, line 728) (in query: SELECT ifNull([]);) 2025.07.13 02:38:59.964668 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 1, should be 2: In scope SELECT ifNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.113314 [ 32979 ] {12a7d88c-8139-44ae-abbc-2b1a6dcb3eee} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 1, should be 2: In scope SELECT ilike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 729, line 730) (in query: SELECT ilike([]);) 2025.07.13 02:39:00.124564 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 1, should be 2: In scope SELECT ilike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.141384 [ 32979 ] {5b484c74-4372-4b5b-92cd-069d43aafd54} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 730, line 731) (in query: SELECT in([]);) 2025.07.13 02:39:00.144965 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.175745 [ 32979 ] {dbcf6d98-795f-4be8-a5a9-31e82deeb9cd} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 731, line 732) (in query: SELECT inIgnoreSet([]);) 2025.07.13 02:39:00.178539 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.242022 [ 32979 ] {4e133ef1-59ab-41e3-82fd-f136c6e3b9b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 1, should be 2: In scope SELECT indexOf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 733, line 734) (in query: SELECT indexOf([]);) 2025.07.13 02:39:00.249758 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 1, should be 2: In scope SELECT indexOf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.287079 [ 32979 ] {e3f1911e-e152-413a-8979-c5b3bec9e9e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 1, should be 2: In scope SELECT indexOfAssumeSorted([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted([]);) 2025.07.13 02:39:00.289615 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 1, should be 2: In scope SELECT indexOfAssumeSorted([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.314948 [ 32979 ] {4050694e-0fb5-4552-8604-00984a5b91fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function initcap: In scope SELECT initcap([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 735, line 736) (in query: SELECT initcap([]);) 2025.07.13 02:39:00.317511 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function initcap: In scope SELECT initcap([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.332683 [ 32979 ] {2251a3ad-778b-461a-b2b0-812f52cf188c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function initcapUTF8: In scope SELECT initcapUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 736, line 737) (in query: SELECT initcapUTF8([]);) 2025.07.13 02:39:00.336154 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function initcapUTF8: In scope SELECT initcapUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.351831 [ 32979 ] {0d5fa62d-ee04-405d-9eec-fd093a21c59f} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initialQueryID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 737, line 738) (in query: SELECT initialQueryID([]);) 2025.07.13 02:39:00.362263 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initialQueryID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.404743 [ 32979 ] {3fe24d37-d7bd-4c86-98e2-9fa855581d63} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initialQueryStartTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime([]);) 2025.07.13 02:39:00.408376 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initialQueryStartTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.436781 [ 32979 ] {195a7746-ff57-4080-8656-25cadee6fe30} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initial_query_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 739, line 740) (in query: SELECT initial_query_id([]);) 2025.07.13 02:39:00.440168 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initial_query_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.458455 [ 32979 ] {21618a7e-9b7b-4d57-9b10-f624497386c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initial_query_start_time([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 740, line 741) (in query: SELECT initial_query_start_time([]);) 2025.07.13 02:39:00.461669 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initial_query_start_time([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.487231 [ 32979 ] {d07f1c82-2dc1-4deb-b002-fa6b65b1e032} executeQuery: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 1, should be at least 2.: In scope SELECT initializeAggregation([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 741, line 742) (in query: SELECT initializeAggregation([]);) 2025.07.13 02:39:00.491054 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 1, should be at least 2.: In scope SELECT initializeAggregation([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.511054 [ 32979 ] {379a5253-64e8-4ec5-8eb8-21915dd0d366} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT instr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 742, line 743) (in query: SELECT instr([]);) 2025.07.13 02:39:00.515338 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT instr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.537441 [ 32979 ] {b9441cac-59f0-4b28-865d-499da1b95fcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 1, should be 2: In scope SELECT intDiv([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 743, line 744) (in query: SELECT intDiv([]);) 2025.07.13 02:39:00.541717 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 1, should be 2: In scope SELECT intDiv([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.568928 [ 32979 ] {a2fbfdd6-9b0f-4e50-bfe5-24a28e706a67} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 1, should be 2: In scope SELECT intDivOrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 744, line 745) (in query: SELECT intDivOrZero([]);) 2025.07.13 02:39:00.573454 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 1, should be 2: In scope SELECT intDivOrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.692288 [ 32979 ] {033690a6-2ec2-45c5-91db-3ae54e81d313} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intExp10: In scope SELECT intExp10([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 745, line 746) (in query: SELECT intExp10([]);) 2025.07.13 02:39:00.699834 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intExp10: In scope SELECT intExp10([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.749571 [ 32979 ] {6829bb26-4422-4cb5-b570-646eec2835a3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intExp2: In scope SELECT intExp2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 746, line 747) (in query: SELECT intExp2([]);) 2025.07.13 02:39:00.765072 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intExp2: In scope SELECT intExp2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.795785 [ 32979 ] {d76841e4-13fe-49a3-a2dc-05423fab515c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intHash32: In scope SELECT intHash32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 747, line 748) (in query: SELECT intHash32([]);) 2025.07.13 02:39:00.799219 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intHash32: In scope SELECT intHash32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.823864 [ 32979 ] {b6bb47d0-a0c5-4912-88c8-58c87ccdfff3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intHash64: In scope SELECT intHash64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 748, line 749) (in query: SELECT intHash64([]);) 2025.07.13 02:39:00.827310 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function intHash64: In scope SELECT intHash64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.858141 [ 32979 ] {f92f6428-6c23-4881-a4dc-a55408580adc} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 749, line 750) (in query: SELECT intervalLengthSum([]);) 2025.07.13 02:39:00.864438 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:00.951830 [ 32979 ] {652a6d8a-c619-4e13-b331-50ccf944b2ca} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isDecimalOverflow: In scope SELECT isDecimalOverflow([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 751, line 752) (in query: SELECT isDecimalOverflow([]);) 2025.07.13 02:39:00.954972 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isDecimalOverflow: In scope SELECT isDecimalOverflow([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:00.981329 [ 32979 ] {95838e6a-366e-411e-9dce-0a2072b4e78c} executeQuery: Code: 43. DB::Exception: First argument for function isDynamicElementInSharedData must be Dynamic, got Array(Nothing) instead: In scope SELECT isDynamicElementInSharedData([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData([]);) 2025.07.13 02:39:00.984527 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function isDynamicElementInSharedData must be Dynamic, got Array(Nothing) instead: In scope SELECT isDynamicElementInSharedData([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.004885 [ 32979 ] {f5640d0a-9ecc-4cfa-bea9-2060e5d0748c} executeQuery: Code: 43. DB::Exception: Argument for function isFinite must be a number: In scope SELECT isFinite([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 753, line 754) (in query: SELECT isFinite([]);) 2025.07.13 02:39:01.007951 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function isFinite must be a number: In scope SELECT isFinite([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.034021 [ 32979 ] {7f4661e2-69cf-49dd-b82f-f956f0b12854} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 1, should be 2: In scope SELECT isIPAddressInRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange([]);) 2025.07.13 02:39:01.142909 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 1, should be 2: In scope SELECT isIPAddressInRange([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:01.193486 [ 32979 ] {d1a88324-256b-4167-9bc6-452397753e33} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isIPv4String: In scope SELECT isIPv4String([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 755, line 756) (in query: SELECT isIPv4String([]);) 2025.07.13 02:39:01.209788 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isIPv4String: In scope SELECT isIPv4String([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.315355 [ 32979 ] {955b993c-f211-4243-91f9-7a03c3bb6ae0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isIPv6String: In scope SELECT isIPv6String([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 756, line 757) (in query: SELECT isIPv6String([]);) 2025.07.13 02:39:01.319453 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isIPv6String: In scope SELECT isIPv6String([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.341362 [ 32979 ] {32bfe5e0-cd1e-4095-ab4c-070e51e4bc9b} executeQuery: Code: 43. DB::Exception: Argument for function isInfinite must be a number: In scope SELECT isInfinite([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 757, line 758) (in query: SELECT isInfinite([]);) 2025.07.13 02:39:01.350698 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function isInfinite must be a number: In scope SELECT isInfinite([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.399466 [ 32979 ] {e3d61694-ffa0-4e88-aa05-315ee105b481} executeQuery: Code: 43. DB::Exception: Argument for function isNaN must be a number: In scope SELECT isNaN([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 758, line 759) (in query: SELECT isNaN([]);) 2025.07.13 02:39:01.402778 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function isNaN must be a number: In scope SELECT isNaN([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.428949 [ 32979 ] {fdfbe6ec-ca6e-42d2-9ff9-a55ad1df7a25} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT isNotDistinctFrom([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom([]);) 2025.07.13 02:39:01.432635 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT isNotDistinctFrom([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:01.787487 [ 32979 ] {c7430d93-b3c2-44b7-ac1b-b924f03ce805} executeQuery: Code: 43. DB::Exception: The first argument of function isValidJSON should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT isValidJSON([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 763, line 764) (in query: SELECT isValidJSON([]);) 2025.07.13 02:39:01.818399 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function isValidJSON should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT isValidJSON([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.851902 [ 32979 ] {8acbf0ac-c5fb-4a55-bf38-077edd2c12c6} executeQuery: Code: 43. DB::Exception: Cannot apply function isValidUTF8 to Array argument: In scope SELECT isValidUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 764, line 765) (in query: SELECT isValidUTF8([]);) 2025.07.13 02:39:01.857221 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function isValidUTF8 to Array argument: In scope SELECT isValidUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:01.888349 [ 32979 ] {da10c54d-f001-4a0b-bfde-40d6631d5d5b} executeQuery: Code: 36. DB::Exception: The argument of function isZeroOrNull must have simple numeric type, possibly Nullable or Null: In scope SELECT isZeroOrNull([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 765, line 766) (in query: SELECT isZeroOrNull([]);) 2025.07.13 02:39:01.893857 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The argument of function isZeroOrNull must have simple numeric type, possibly Nullable or Null: In scope SELECT isZeroOrNull([]). (BAD_ARGUMENTS) 2025.07.13 02:39:01.932854 [ 32979 ] {4d2ca7cb-1a1b-4272-b07a-2c98ea638244} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroSimilarity([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 766, line 767) (in query: SELECT jaroSimilarity([]);) 2025.07.13 02:39:01.940201 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroSimilarity([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:01.966314 [ 32979 ] {e728d750-e13a-4498-890a-2c831a15cfcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroWinklerSimilarity([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity([]);) 2025.07.13 02:39:01.970998 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroWinklerSimilarity([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.138382 [ 32979 ] {a8477ae4-0d80-40c6-b328-a6cf177edf4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGet([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 770, line 771) (in query: SELECT joinGet([]);) 2025.07.13 02:39:02.141798 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGet([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.179652 [ 32979 ] {933af432-95bd-4652-b964-b7de361c0eb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGetOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 771, line 772) (in query: SELECT joinGetOrNull([]);) 2025.07.13 02:39:02.185502 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGetOrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.211406 [ 32979 ] {4bf37584-462b-42ce-9a21-c40421068cd5} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 772, line 773) (in query: SELECT jsonMergePatch([]);) 2025.07.13 02:39:02.217612 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:02.231513 [ 32979 ] {275556ec-24b2-4aea-862f-4bda4834037d} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 1, should be 2: In scope SELECT jumpConsistentHash([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash([]);) 2025.07.13 02:39:02.234118 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 1, should be 2: In scope SELECT jumpConsistentHash([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.286775 [ 32979 ] {3db41296-7d16-4ae4-89da-075428749f08} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function keccak256: In scope SELECT keccak256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 775, line 776) (in query: SELECT keccak256([]);) 2025.07.13 02:39:02.291470 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function keccak256: In scope SELECT keccak256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:02.318937 [ 32979 ] {b9f32526-ea98-4a7b-a924-fb8b58063d45} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 776, line 777) (in query: SELECT kolmogorovSmirnovTest([]);) 2025.07.13 02:39:02.324681 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.360321 [ 32979 ] {3310233f-1eb9-4525-8c06-8a70bbfefe65} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT kostikConsistentHash([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash([]);) 2025.07.13 02:39:02.365777 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT kostikConsistentHash([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.491117 [ 32979 ] {9cfccc82-cf5d-4dc5-9c18-bf2ed880e612} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function kurtPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 780, line 781) (in query: SELECT kurtPop([]);) 2025.07.13 02:39:02.495707 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function kurtPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:02.527409 [ 32979 ] {d5cc2f37-d258-46cc-8565-5b9fe9d8fc2b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function kurtSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 781, line 782) (in query: SELECT kurtSamp([]);) 2025.07.13 02:39:02.536214 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function kurtSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:02.595649 [ 32979 ] {704e3fad-4350-4bbf-ae41-38d2961b3897} executeQuery: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 782, line 783) (in query: SELECT lagInFrame([]);) 2025.07.13 02:39:02.598518 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:39:02.617993 [ 32979 ] {ab5cfb7e-f22d-47b8-b729-922fef6a703e} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 783, line 784) (in query: SELECT largestTriangleThreeBuckets([]);) 2025.07.13 02:39:02.620995 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:02.906547 [ 32979 ] {918b8a6b-91f9-4897-9b5f-1af814134707} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lower: In scope SELECT lcase([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 787, line 788) (in query: SELECT lcase([]);) 2025.07.13 02:39:02.960649 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lower: In scope SELECT lcase([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:02.999732 [ 32979 ] {c2e42032-e98b-499f-a286-98f9c4e9ec53} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 1, should be 2: In scope SELECT lcm([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 788, line 789) (in query: SELECT lcm([]);) 2025.07.13 02:39:03.007214 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 1, should be 2: In scope SELECT lcm([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.112013 [ 32979 ] {6ac46b17-a060-4cdc-bd8f-f45fb26591a7} executeQuery: Code: 36. DB::Exception: The function 'leadInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 789, line 790) (in query: SELECT leadInFrame([]);) 2025.07.13 02:39:03.116673 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'leadInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:39:03.207889 [ 32979 ] {c76ee42f-f901-4606-84ec-fd72f45b00e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 1, should be 2: In scope SELECT left([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 791, line 792) (in query: SELECT left([]);) 2025.07.13 02:39:03.214727 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 1, should be 2: In scope SELECT left([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.327698 [ 32979 ] {0913c589-b7a6-478c-837e-d746b4280193} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 792, line 793) (in query: SELECT leftPad([]);) 2025.07.13 02:39:03.332173 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.377009 [ 32979 ] {00dcf03c-6709-4900-b8b0-2dffa3e6ecd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPadUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 793, line 794) (in query: SELECT leftPadUTF8([]);) 2025.07.13 02:39:03.382479 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPadUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.405453 [ 32979 ] {22b94e55-ddfc-4bbd-9292-7162f58292f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 1, should be 2: In scope SELECT leftUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 794, line 795) (in query: SELECT leftUTF8([]);) 2025.07.13 02:39:03.415129 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 1, should be 2: In scope SELECT leftUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.440027 [ 32979 ] {e65787a3-3ad9-4efd-b5b2-cfa64c6082bc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 795, line 796) (in query: SELECT lemmatize([]);) 2025.07.13 02:39:03.442404 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:39:03.499706 [ 32979 ] {98d5f293-e773-43c2-a8c9-9d66e5912eb5} executeQuery: Code: 43. DB::Exception: Cannot apply function lengthUTF8 to Array argument: In scope SELECT lengthUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 797, line 798) (in query: SELECT lengthUTF8([]);) 2025.07.13 02:39:03.502350 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot apply function lengthUTF8 to Array argument: In scope SELECT lengthUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:03.521668 [ 32979 ] {203bcf21-b1c2-417d-97bd-4722fb2c3551} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 1, should be 2: In scope SELECT less([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 798, line 799) (in query: SELECT less([]);) 2025.07.13 02:39:03.524679 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 1, should be 2: In scope SELECT less([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.550539 [ 32979 ] {395b550b-2b43-4f9d-9a5b-6e3184d653a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 1, should be 2: In scope SELECT lessOrEquals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 799, line 800) (in query: SELECT lessOrEquals([]);) 2025.07.13 02:39:03.559086 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 1, should be 2: In scope SELECT lessOrEquals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.580480 [ 32979 ] {f9657c0f-b29c-4f01-b095-f11c2367a690} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 800, line 801) (in query: SELECT levenshteinDistance([]);) 2025.07.13 02:39:03.583524 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.616493 [ 32979 ] {3430cd8b-de29-4972-a920-5ed04f2db446} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistanceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8([]);) 2025.07.13 02:39:03.620165 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistanceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.644093 [ 32979 ] {fbcbaa84-7d05-4c67-a05f-7d63a679e68d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lgamma: In scope SELECT lgamma([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 802, line 803) (in query: SELECT lgamma([]);) 2025.07.13 02:39:03.647409 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lgamma: In scope SELECT lgamma([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:03.663731 [ 32979 ] {47a6a34a-080b-42e8-9a01-6281a9c201dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 1, should be 2: In scope SELECT like([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 803, line 804) (in query: SELECT like([]);) 2025.07.13 02:39:03.667746 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 1, should be 2: In scope SELECT like([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.689199 [ 32979 ] {b6bb7422-700e-4cf3-a0f5-436f63d5caa4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log: In scope SELECT ln([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 804, line 805) (in query: SELECT ln([]);) 2025.07.13 02:39:03.694161 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log: In scope SELECT ln([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:03.747631 [ 32979 ] {e6462775-d21a-48ab-a5d7-333363ad9fd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 1, should be 2 or 3: In scope SELECT locate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 805, line 806) (in query: SELECT locate([]);) 2025.07.13 02:39:03.765450 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 1, should be 2 or 3: In scope SELECT locate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:03.812739 [ 32979 ] {40b9f029-a752-48ee-8b65-c32c17b73a77} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log: In scope SELECT log([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 806, line 807) (in query: SELECT log([]);) 2025.07.13 02:39:03.822755 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log: In scope SELECT log([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:03.872664 [ 32979 ] {16bfdc62-187d-4620-b3d3-55141cf583c5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log10: In scope SELECT log10([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 807, line 808) (in query: SELECT log10([]);) 2025.07.13 02:39:03.876925 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log10: In scope SELECT log10([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:03.911334 [ 32979 ] {0e3c693e-e638-44db-8a46-a3df3550813d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log1p: In scope SELECT log1p([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 808, line 809) (in query: SELECT log1p([]);) 2025.07.13 02:39:03.915456 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log1p: In scope SELECT log1p([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.019759 [ 32979 ] {38dba17f-bf90-4dc8-a139-4abb318c65a5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log2: In scope SELECT log2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 809, line 810) (in query: SELECT log2([]);) 2025.07.13 02:39:04.082155 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function log2: In scope SELECT log2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.099003 [ 32979 ] {ce7e7435-19d5-4cdb-b184-bd8cc8a74a34} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function logTrace: In scope SELECT logTrace([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 810, line 811) (in query: SELECT logTrace([]);) 2025.07.13 02:39:04.102661 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function logTrace: In scope SELECT logTrace([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.119881 [ 32979 ] {c4472374-873c-4008-a3ec-0a8625c60997} executeQuery: Code: 43. DB::Exception: First first argument of function lowCardinalityIndexes must be ColumnLowCardinality, but got Array(Nothing): In scope SELECT lowCardinalityIndices([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices([]);) 2025.07.13 02:39:04.123213 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First first argument of function lowCardinalityIndexes must be ColumnLowCardinality, but got Array(Nothing): In scope SELECT lowCardinalityIndices([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.144224 [ 32979 ] {c0ae2651-d97d-4874-89da-6e578d5c17b1} executeQuery: Code: 43. DB::Exception: First first argument of function lowCardinalityKeys must be ColumnLowCardinality, but got Array(Nothing): In scope SELECT lowCardinalityKeys([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys([]);) 2025.07.13 02:39:04.147522 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First first argument of function lowCardinalityKeys must be ColumnLowCardinality, but got Array(Nothing): In scope SELECT lowCardinalityKeys([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.165830 [ 32979 ] {41c77e03-1a42-46d3-ad6e-04548f63c110} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lower: In scope SELECT lower([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 813, line 814) (in query: SELECT lower([]);) 2025.07.13 02:39:04.169231 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lower: In scope SELECT lower([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.186357 [ 32979 ] {18f4bf4b-8a5a-4a12-ad9a-5b71c9f0ad9d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lowerUTF8: In scope SELECT lowerUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 814, line 815) (in query: SELECT lowerUTF8([]);) 2025.07.13 02:39:04.283418 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function lowerUTF8: In scope SELECT lowerUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.302567 [ 32979 ] {78f5d6cd-2aa0-461b-aa58-73c5b1c174f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT lpad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 815, line 816) (in query: SELECT lpad([]);) 2025.07.13 02:39:04.306165 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT lpad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.322232 [ 32979 ] {c3dc4914-6311-450a-9299-2670e0bff9d1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Array(Nothing): In scope SELECT trimLeft([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 816, line 817) (in query: SELECT ltrim([]);) 2025.07.13 02:39:04.325402 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Array(Nothing): In scope SELECT trimLeft([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.341579 [ 32979 ] {c79902cd-7f8a-4b8f-b2e3-01c22f9ecade} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 817, line 818) (in query: SELECT lttb([]);) 2025.07.13 02:39:04.370349 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.402881 [ 32979 ] {e4f98d30-9de3-4939-9f3d-591305608b52} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 818, line 819) (in query: SELECT makeDate([]);) 2025.07.13 02:39:04.407852 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.437329 [ 32979 ] {4e236a8d-0edf-4904-8424-ccad3cd0ad16} 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([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 819, line 820) (in query: SELECT makeDate32([]);) 2025.07.13 02:39:04.442721 [ 32979 ] {} 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([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.470589 [ 32979 ] {bb1bb272-21a9-402f-b5af-2ae40f0c6acf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT makeDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 820, line 821) (in query: SELECT makeDateTime([]);) 2025.07.13 02:39:04.475453 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT makeDateTime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.651883 [ 32979 ] {26ab173e-d1bb-4845-ab67-88137639a888} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 1 argument: In scope SELECT makeDateTime64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 821, line 822) (in query: SELECT makeDateTime64([]);) 2025.07.13 02:39:04.663162 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 1 argument: In scope SELECT makeDateTime64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.691578 [ 32979 ] {bc5ebc32-d19d-4180-aab4-b59789cf051d} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 822, line 823) (in query: SELECT mannWhitneyUTest([]);) 2025.07.13 02:39:04.696233 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.716652 [ 32979 ] {f19ede20-71d1-4956-b921-3280fdd8a5f5} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 1 given: In scope SELECT map([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 823, line 824) (in query: SELECT map([]);) 2025.07.13 02:39:04.720453 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 1 given: In scope SELECT map([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.742351 [ 32979 ] {1a8bd4df-e638-4bab-96b4-4fede331e5f2} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 824, line 825) (in query: SELECT mapAdd([]);) 2025.07.13 02:39:04.746293 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.781670 [ 32979 ] {d995ec80-995a-493a-8855-bdf9ff2d212a} executeQuery: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 825, line 826) (in query: SELECT mapAll([]);) 2025.07.13 02:39:04.785545 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.837829 [ 32979 ] {1de54a5d-9103-4588-bcd1-256bc156faf4} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 826, line 827) (in query: SELECT mapApply([]);) 2025.07.13 02:39:04.840585 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.858011 [ 32979 ] {78a29a48-0dcd-4ac1-8a14-8c9d13119727} executeQuery: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 827, line 828) (in query: SELECT mapConcat([]);) 2025.07.13 02:39:04.864317 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.884672 [ 32979 ] {cd5465d6-aeb4-4bd8-a4ab-ecb00a5ad5a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 1, should be 2: In scope SELECT mapContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 828, line 829) (in query: SELECT mapContains([]);) 2025.07.13 02:39:04.892154 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 1, should be 2: In scope SELECT mapContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.909066 [ 32979 ] {7183f6b4-c4a1-4366-b961-8d3c725317df} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapContainsKeyLike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 829, line 830) (in query: SELECT mapContainsKeyLike([]);) 2025.07.13 02:39:04.914615 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapContainsKeyLike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:04.935714 [ 32979 ] {6d082246-2293-4aab-a66e-5909d429941a} executeQuery: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 830, line 831) (in query: SELECT mapExists([]);) 2025.07.13 02:39:04.939128 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:04.955877 [ 32979 ] {150a314d-9043-4998-95ab-3fb3e4f56680} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapExtractKeyLike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 831, line 832) (in query: SELECT mapExtractKeyLike([]);) 2025.07.13 02:39:04.958859 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapExtractKeyLike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.062815 [ 32979 ] {8f7d9d78-c345-480e-9ead-4816cc01fb04} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 832, line 833) (in query: SELECT mapFilter([]);) 2025.07.13 02:39:05.067965 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.098526 [ 32979 ] {f6527e9b-814f-4442-8b5a-2efba5f82b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT mapFromArrays([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 833, line 834) (in query: SELECT mapFromArrays([]);) 2025.07.13 02:39:05.112083 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT mapFromArrays([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.145142 [ 32979 ] {19bd2655-5ed6-4227-a7b7-9a29a126ec6a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT mapFromString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 834, line 835) (in query: SELECT mapFromString([]);) 2025.07.13 02:39:05.149597 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT mapFromString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.172395 [ 32979 ] {ac78e6d9-2939-4713-b4c9-cacf43df695b} executeQuery: Code: 43. DB::Exception: Function mapKeys requires at least one argument of type Map: In scope SELECT mapKeys([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 835, line 836) (in query: SELECT mapKeys([]);) 2025.07.13 02:39:05.176903 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapKeys requires at least one argument of type Map: In scope SELECT mapKeys([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.203511 [ 32979 ] {27d0c569-a814-455a-bff3-43fa4022cd56} executeQuery: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 836, line 837) (in query: SELECT mapPartialReverseSort([]);) 2025.07.13 02:39:05.216605 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.242538 [ 32979 ] {16df14cf-12fb-4bad-b890-614a5c736317} executeQuery: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 837, line 838) (in query: SELECT mapPartialSort([]);) 2025.07.13 02:39:05.250275 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.282080 [ 32979 ] {f045027d-eae6-45fd-b8d1-8cc7c09fa93c} executeQuery: Code: 36. DB::Exception: Function mapPopulateSeries if array argument is passed as key, additional array argument as value must be passed: In scope SELECT mapPopulateSeries([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 838, line 839) (in query: SELECT mapPopulateSeries([]);) 2025.07.13 02:39:05.286880 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Function mapPopulateSeries if array argument is passed as key, additional array argument as value must be passed: In scope SELECT mapPopulateSeries([]). (BAD_ARGUMENTS) 2025.07.13 02:39:05.325122 [ 32979 ] {2e3b1cd9-f6dc-4f3c-bc13-5c4911a66f6d} executeQuery: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 839, line 840) (in query: SELECT mapReverseSort([]);) 2025.07.13 02:39:05.328418 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.360806 [ 32979 ] {0190d3e5-42b9-4d58-b6f8-349da1d8aca2} executeQuery: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 840, line 841) (in query: SELECT mapSort([]);) 2025.07.13 02:39:05.364028 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.383302 [ 32979 ] {95add758-ab82-467b-b31a-f628bdf056a6} executeQuery: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 841, line 842) (in query: SELECT mapSubtract([]);) 2025.07.13 02:39:05.385638 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.400360 [ 32979 ] {55ea4b29-80a5-476e-a174-114ab2e0ae29} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 1, should be 2: In scope SELECT mapUpdate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 842, line 843) (in query: SELECT mapUpdate([]);) 2025.07.13 02:39:05.419216 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 1, should be 2: In scope SELECT mapUpdate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.454867 [ 32979 ] {634803f9-da72-4064-8c44-31dad7a1b643} executeQuery: Code: 43. DB::Exception: Function mapValues requires at least one argument of type Map: In scope SELECT mapValues([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 843, line 844) (in query: SELECT mapValues([]);) 2025.07.13 02:39:05.465430 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Function mapValues requires at least one argument of type Map: In scope SELECT mapValues([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.492582 [ 32979 ] {4d25cb4c-054e-4b6f-bef7-eda6b7958b02} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT match([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 844, line 845) (in query: SELECT match([]);) 2025.07.13 02:39:05.495797 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT match([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.680266 [ 32979 ] {500754c1-127f-46c6-a2c4-c1c0beb450a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 1, should be 2: In scope SELECT max2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 847, line 848) (in query: SELECT max2([]);) 2025.07.13 02:39:05.684337 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 1, should be 2: In scope SELECT max2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.725922 [ 32979 ] {0bcb3769-079b-4089-aadb-8022f6bee589} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 848, line 849) (in query: SELECT maxIntersections([]);) 2025.07.13 02:39:05.730715 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.748868 [ 32979 ] {89ecafa6-a556-4054-bd4e-4cae3945e5a1} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 849, line 850) (in query: SELECT maxIntersectionsPosition([]);) 2025.07.13 02:39:05.752236 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.769492 [ 32979 ] {d45cb204-b7ff-4db5-ba83-203c983b354d} executeQuery: Code: 43. DB::Exception: When function maxMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 850, line 851) (in query: SELECT maxMappedArrays([]);) 2025.07.13 02:39:05.771941 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: When function maxMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.797875 [ 32979 ] {138ed42a-1c75-4743-87fa-c1ba5a49840b} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 851, line 852) (in query: SELECT meanZTest([]);) 2025.07.13 02:39:05.802379 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:05.822215 [ 32979 ] {b6324fab-188a-4ce1-a05f-6838514701f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 852, line 853) (in query: SELECT median([]);) 2025.07.13 02:39:05.830090 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.881177 [ 32979 ] {a54e1942-4271-4b5f-acb5-c1b08824b825} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 853, line 854) (in query: SELECT medianBFloat16([]);) 2025.07.13 02:39:05.901354 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:05.946125 [ 32979 ] {f3bfe1fb-8517-4a55-8f56-4d79dbb7e1c8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 854, line 855) (in query: SELECT medianBFloat16Weighted([]);) 2025.07.13 02:39:05.952526 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.038275 [ 32979 ] {e50fe5ac-01ef-4621-802f-c2ea318777a1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 855, line 856) (in query: SELECT medianDD([]);) 2025.07.13 02:39:06.040953 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.067022 [ 32979 ] {f672825e-b251-4289-97be-65439d3566f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 856, line 857) (in query: SELECT medianDeterministic([]);) 2025.07.13 02:39:06.074201 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.143927 [ 32979 ] {d347bccb-1aba-4e4c-8995-9d921d9be474} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 857, line 858) (in query: SELECT medianExact([]);) 2025.07.13 02:39:06.153019 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.220697 [ 32979 ] {5b89d567-b0dd-4dad-a6f6-47fbe87db182} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 858, line 859) (in query: SELECT medianExactHigh([]);) 2025.07.13 02:39:06.225590 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.255336 [ 32979 ] {47e1e828-d0c2-4015-953f-0aa98a3606c1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 859, line 860) (in query: SELECT medianExactLow([]);) 2025.07.13 02:39:06.261071 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.292003 [ 32979 ] {304e4438-b4cc-4f04-84d4-6f8e171e78db} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 860, line 861) (in query: SELECT medianExactWeighted([]);) 2025.07.13 02:39:06.298061 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.378318 [ 32979 ] {311e1314-32e0-4bd7-820b-8112a0c60a67} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 861, line 862) (in query: SELECT medianExactWeightedInterpolated([]);) 2025.07.13 02:39:06.382891 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.416631 [ 32979 ] {d4185983-07b1-4a04-aa92-57747bc6be22} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 862, line 863) (in query: SELECT medianGK([]);) 2025.07.13 02:39:06.421058 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.527593 [ 32979 ] {d44e6089-ace8-48c0-97f2-b0c889a62a9b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 863, line 864) (in query: SELECT medianInterpolatedWeighted([]);) 2025.07.13 02:39:06.530396 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.556541 [ 32979 ] {7cd63c79-0e19-4243-8829-7f214ffefe53} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 864, line 865) (in query: SELECT medianTDigest([]);) 2025.07.13 02:39:06.558740 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.600673 [ 32979 ] {e2b31e04-be3c-4c23-8896-de383b1c3a33} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 865, line 866) (in query: SELECT medianTDigestWeighted([]);) 2025.07.13 02:39:06.603886 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.642877 [ 32979 ] {e2dbcb62-6ed4-4a67-8ced-b1ec637f5834} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 866, line 867) (in query: SELECT medianTiming([]);) 2025.07.13 02:39:06.646518 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.671062 [ 32979 ] {8615a225-9d16-47dd-8346-a7f7e0ee00a4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 867, line 868) (in query: SELECT medianTimingWeighted([]);) 2025.07.13 02:39:06.676774 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:06.805685 [ 32979 ] {a472486d-9b7d-4ae9-ac32-c43ed9405914} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT mid([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 869, line 870) (in query: SELECT mid([]);) 2025.07.13 02:39:06.809565 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT mid([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.008165 [ 32979 ] {f6988e44-96d8-49d1-8298-bdf4ce7a3fb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 1, should be 2: In scope SELECT min2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 871, line 872) (in query: SELECT min2([]);) 2025.07.13 02:39:07.015896 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 1, should be 2: In scope SELECT min2([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.041225 [ 32979 ] {ff27b3c0-a050-4908-82a7-061fdbc0d4b2} executeQuery: Code: 43. DB::Exception: When function minMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 872, line 873) (in query: SELECT minMappedArrays([]);) 2025.07.13 02:39:07.045802 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: When function minMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:07.086724 [ 32979 ] {1fc946c6-2d38-4f0b-9343-bc6a71166b63} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinous([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 873, line 874) (in query: SELECT minSampleSizeContinous([]);) 2025.07.13 02:39:07.090250 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinous([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.108014 [ 32979 ] {391df8ee-d7d4-4b90-a83e-a4e43252adc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinuous([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 874, line 875) (in query: SELECT minSampleSizeContinuous([]);) 2025.07.13 02:39:07.112007 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinuous([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.141419 [ 32979 ] {f628c051-8935-409e-92bf-aa223c77c809} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 1, should be 4: In scope SELECT minSampleSizeConversion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 875, line 876) (in query: SELECT minSampleSizeConversion([]);) 2025.07.13 02:39:07.144788 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 1, should be 4: In scope SELECT minSampleSizeConversion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.162705 [ 32979 ] {3ae22a62-0d44-42b2-82e6-62d76af6dc7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 1, should be 2: In scope SELECT minus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 876, line 877) (in query: SELECT minus([]);) 2025.07.13 02:39:07.166118 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 1, should be 2: In scope SELECT minus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.184081 [ 32979 ] {10ea00ea-637f-46ee-95cf-1c7d89c14335} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT mismatches([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 877, line 878) (in query: SELECT mismatches([]);) 2025.07.13 02:39:07.188158 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT mismatches([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.236582 [ 32979 ] {11e67564-f86b-4953-a41f-49ae1e4d47e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT mod([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 878, line 879) (in query: SELECT mod([]);) 2025.07.13 02:39:07.239945 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT mod([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.259654 [ 32979 ] {73fcd036-0063-40ad-91f8-3761932ca43b} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT modulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 879, line 880) (in query: SELECT modulo([]);) 2025.07.13 02:39:07.413148 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT modulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.479607 [ 32979 ] {022426a2-3616-49c0-a2f6-aebef374098f} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 1, should be 2: In scope SELECT moduloLegacy([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 880, line 881) (in query: SELECT moduloLegacy([]);) 2025.07.13 02:39:07.483705 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 1, should be 2: In scope SELECT moduloLegacy([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.517468 [ 32979 ] {d4f22321-2804-4234-8e60-70bbeee8eae4} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 1, should be 2: In scope SELECT moduloOrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 881, line 882) (in query: SELECT moduloOrZero([]);) 2025.07.13 02:39:07.524016 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 1, should be 2: In scope SELECT moduloOrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.581668 [ 32979 ] {9508af9c-4d2d-4bbc-a7ca-64c24f93a216} executeQuery: Code: 43. DB::Exception: Illegal type of argument of function monthName, should be Date, DateTime or DateTime64: In scope SELECT monthName([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 882, line 883) (in query: SELECT monthName([]);) 2025.07.13 02:39:07.620502 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of argument of function monthName, should be Date, DateTime or DateTime64: In scope SELECT monthName([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:07.701726 [ 32979 ] {8753eaf2-9143-4724-bc49-480a579c4818} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 1, should be 2: In scope SELECT mortonDecode([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 883, line 884) (in query: SELECT mortonDecode([]);) 2025.07.13 02:39:07.705773 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 1, should be 2: In scope SELECT mortonDecode([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.724753 [ 32979 ] {afeec50e-ca92-4494-a564-445c6726a6c0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 884, line 885) (in query: SELECT mortonEncode([]);) 2025.07.13 02:39:07.731294 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:07.761313 [ 32979 ] {8bcd7519-0a6b-45fb-970c-a8897ccc72f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAllIndices([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 885, line 886) (in query: SELECT multiFuzzyMatchAllIndices([]);) 2025.07.13 02:39:07.765294 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAllIndices([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.815530 [ 32979 ] {bc84518e-4b9d-4cf6-977c-427dce3d28f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 886, line 887) (in query: SELECT multiFuzzyMatchAny([]);) 2025.07.13 02:39:07.825224 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.850203 [ 32979 ] {e62d6d0f-44ef-483b-8e2d-f874260ca79d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAnyIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 887, line 888) (in query: SELECT multiFuzzyMatchAnyIndex([]);) 2025.07.13 02:39:07.855876 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAnyIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.900333 [ 32979 ] {7cfa2578-3240-4aed-813b-b7972ff199d0} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 888, line 889) (in query: SELECT multiIf([]);) 2025.07.13 02:39:07.907818 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.939070 [ 32979 ] {f8522f19-2895-4534-a471-87e61a594ca0} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 1, should be 2: In scope SELECT multiMatchAllIndices([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 889, line 890) (in query: SELECT multiMatchAllIndices([]);) 2025.07.13 02:39:07.947659 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 1, should be 2: In scope SELECT multiMatchAllIndices([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:07.991808 [ 32979 ] {64cea682-4061-4653-8b00-e5bc9fc094fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 1, should be 2: In scope SELECT multiMatchAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 890, line 891) (in query: SELECT multiMatchAny([]);) 2025.07.13 02:39:07.996103 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 1, should be 2: In scope SELECT multiMatchAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.020389 [ 32979 ] {72b0fc76-65fe-4456-a48a-40d4d16a5c82} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 1, should be 2: In scope SELECT multiMatchAnyIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 891, line 892) (in query: SELECT multiMatchAnyIndex([]);) 2025.07.13 02:39:08.024334 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 1, should be 2: In scope SELECT multiMatchAnyIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.051926 [ 32979 ] {88a2aaf7-3217-4199-91d6-b8c7ca2b6951} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositions([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 892, line 893) (in query: SELECT multiSearchAllPositions([]);) 2025.07.13 02:39:08.055831 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositions([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.089750 [ 32979 ] {c82560eb-0673-403a-8251-f93a65a450fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 893, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive([]);) 2025.07.13 02:39:08.094273 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.116490 [ 32979 ] {f26acd16-aaf1-43be-8b42-7328a0b9dce8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 894, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8([]);) 2025.07.13 02:39:08.124151 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.145170 [ 32979 ] {437ff98b-9541-4361-b92f-61dc8b87f246} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 895, line 896) (in query: SELECT multiSearchAllPositionsUTF8([]);) 2025.07.13 02:39:08.148653 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.270904 [ 32979 ] {e389409b-3592-4f05-9c30-0c7703485ba1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 1, should be 2: In scope SELECT multiSearchAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 896, line 897) (in query: SELECT multiSearchAny([]);) 2025.07.13 02:39:08.274767 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 1, should be 2: In scope SELECT multiSearchAny([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.358549 [ 32979 ] {aa9dea7a-c7ac-42f4-bc27-59e0b1c92d95} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 897, line 898) (in query: SELECT multiSearchAnyCaseInsensitive([]);) 2025.07.13 02:39:08.363772 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.406596 [ 32979 ] {f417f40e-c45b-41e7-be4b-6f17c874e544} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 898, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8([]);) 2025.07.13 02:39:08.411310 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.438460 [ 32979 ] {32a31148-879c-4d15-ba99-62c4ab57775f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 899, line 900) (in query: SELECT multiSearchAnyUTF8([]);) 2025.07.13 02:39:08.442576 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.469998 [ 32979 ] {ff8e007d-7936-44eb-b885-25a3668d4590} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 900, line 901) (in query: SELECT multiSearchFirstIndex([]);) 2025.07.13 02:39:08.475214 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.507325 [ 32979 ] {e4931aa0-c67e-4c61-9541-4af30728ec30} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 901, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive([]);) 2025.07.13 02:39:08.512080 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.540116 [ 32979 ] {c6078eba-7909-45d3-8893-ebb451843cf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 902, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8([]);) 2025.07.13 02:39:08.546711 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.640917 [ 32979 ] {9dc5e594-5eaf-4b9c-92ab-0577cce8d961} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 903, line 904) (in query: SELECT multiSearchFirstIndexUTF8([]);) 2025.07.13 02:39:08.646172 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.773267 [ 32979 ] {4c651f9b-aae1-449c-a531-271809f9479d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPosition([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 904, line 905) (in query: SELECT multiSearchFirstPosition([]);) 2025.07.13 02:39:08.792945 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPosition([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.822531 [ 32979 ] {949ec17c-28af-4f7f-a6df-d307c372710e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 905, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive([]);) 2025.07.13 02:39:08.840339 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.887232 [ 32979 ] {085c8a48-84a1-4d61-99d8-8630e6c16a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 906, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8([]);) 2025.07.13 02:39:08.894818 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.936255 [ 32979 ] {12d5b81b-c30d-4ff2-93bb-08ea3aaaa5cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 907, line 908) (in query: SELECT multiSearchFirstPositionUTF8([]);) 2025.07.13 02:39:08.942345 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:08.971555 [ 32979 ] {70160942-0b7c-46b6-9665-601adb147d56} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT multiply([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 908, line 909) (in query: SELECT multiply([]);) 2025.07.13 02:39:08.976051 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT multiply([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:09.008520 [ 32979 ] {962bfaa4-4587-46c7-86a9-a8c9956b0d0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 909, line 910) (in query: SELECT multiplyDecimal([]);) 2025.07.13 02:39:09.012997 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:09.376644 [ 32979 ] {8ac3f1cd-ea0b-4248-8926-d3ab733f421e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function negate: In scope SELECT -[]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 915, line 916) (in query: SELECT negate([]);) 2025.07.13 02:39:09.381494 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function negate: In scope SELECT -[]. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.409730 [ 32979 ] {6dd90fea-e024-4e32-b8ca-d0ec27a61a3c} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 916, line 917) (in query: SELECT neighbor([]);) 2025.07.13 02:39:09.413989 [ 32979 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.07.13 02:39:09.442503 [ 32979 ] {f22d7024-d01c-4629-b5b1-8bc590349876} executeQuery: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 1, should be at least 2: In scope SELECT nested([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 917, line 918) (in query: SELECT nested([]);) 2025.07.13 02:39:09.446252 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 1, should be at least 2: In scope SELECT nested([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:09.472080 [ 32979 ] {2552b7d8-5b03-4484-91e2-594bbd0fe953} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function netloc: In scope SELECT netloc([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 918, line 919) (in query: SELECT netloc([]);) 2025.07.13 02:39:09.475303 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function netloc: In scope SELECT netloc([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.494712 [ 32979 ] {6f934080-e586-4b8b-a254-6d96f1063ac6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 1, should be 2: In scope SELECT ngramDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 919, line 920) (in query: SELECT ngramDistance([]);) 2025.07.13 02:39:09.497862 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 1, should be 2: In scope SELECT ngramDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:09.516560 [ 32979 ] {96402c0d-19cf-444e-adc9-9da48c719234} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 920, line 921) (in query: SELECT ngramDistanceCaseInsensitive([]);) 2025.07.13 02:39:09.520062 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:09.549345 [ 32979 ] {d1966f4c-0b9c-4ff7-b6b3-3d7d17d237c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 921, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8([]);) 2025.07.13 02:39:09.645932 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:09.667170 [ 32979 ] {9fcc2e81-7cef-4253-96f2-40770989a31d} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 922, line 923) (in query: SELECT ngramDistanceUTF8([]);) 2025.07.13 02:39:09.670784 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:09.708959 [ 32979 ] {b8c7a4eb-936f-4095-848e-560d347d5cfb} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nothing): In scope SELECT ngramMinHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 923, line 924) (in query: SELECT ngramMinHash([]);) 2025.07.13 02:39:09.712884 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nothing): In scope SELECT ngramMinHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.736845 [ 32979 ] {4cad658f-28ae-4fa9-b256-21c7abb39b91} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nothing): In scope SELECT ngramMinHashArg([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 924, line 925) (in query: SELECT ngramMinHashArg([]);) 2025.07.13 02:39:09.740775 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nothing): In scope SELECT ngramMinHashArg([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.773181 [ 32979 ] {9483f463-c969-4c61-8d41-d0984ec0767e} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 925, line 926) (in query: SELECT ngramMinHashArgCaseInsensitive([]);) 2025.07.13 02:39:09.782361 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.819933 [ 32979 ] {4650c4eb-23a8-4fb8-a402-c227d16c666f} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 926, line 927) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8([]);) 2025.07.13 02:39:09.833788 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.866792 [ 32979 ] {056ca942-9182-4a9a-8cca-d1b88f64502a} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 927, line 928) (in query: SELECT ngramMinHashArgUTF8([]);) 2025.07.13 02:39:09.871499 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.896659 [ 32979 ] {67c57ed9-02dd-4979-93a4-13d4d0f9b686} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 928, line 929) (in query: SELECT ngramMinHashCaseInsensitive([]);) 2025.07.13 02:39:09.900473 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.930846 [ 32979 ] {ac69da14-8666-449d-a67d-f88ba561ad0d} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 929, line 930) (in query: SELECT ngramMinHashCaseInsensitiveUTF8([]);) 2025.07.13 02:39:09.934011 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.953594 [ 32979 ] {b7bc985d-fc2c-4394-ad14-144d0d9e2bfd} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 930, line 931) (in query: SELECT ngramMinHashUTF8([]);) 2025.07.13 02:39:09.957537 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:09.995371 [ 32979 ] {02456ddd-9676-4494-bd8e-320d78b92094} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 1, should be 2: In scope SELECT ngramSearch([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 931, line 932) (in query: SELECT ngramSearch([]);) 2025.07.13 02:39:09.999329 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 1, should be 2: In scope SELECT ngramSearch([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.025218 [ 32979 ] {361629eb-f587-4c68-b57c-6d3427f4c705} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 932, line 933) (in query: SELECT ngramSearchCaseInsensitive([]);) 2025.07.13 02:39:10.029660 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.155940 [ 32979 ] {9be95d30-509d-4509-9b82-269f03a76a82} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 933, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8([]);) 2025.07.13 02:39:10.159856 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.179618 [ 32979 ] {f81787c4-1187-4e53-a944-482c1210a787} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 934, line 935) (in query: SELECT ngramSearchUTF8([]);) 2025.07.13 02:39:10.182934 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.199834 [ 32979 ] {fa677293-aa0c-43e4-b64f-cc8f2d39768a} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nothing): In scope SELECT ngramSimHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 935, line 936) (in query: SELECT ngramSimHash([]);) 2025.07.13 02:39:10.203206 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nothing): In scope SELECT ngramSimHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.220895 [ 32979 ] {9f0ba147-81c5-4bdf-a932-00669744798a} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 936, line 937) (in query: SELECT ngramSimHashCaseInsensitive([]);) 2025.07.13 02:39:10.224453 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.251350 [ 32979 ] {25a54db4-f6a0-4509-966c-3635b9063c6b} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 937, line 938) (in query: SELECT ngramSimHashCaseInsensitiveUTF8([]);) 2025.07.13 02:39:10.256159 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.303876 [ 32979 ] {570ad58e-2a47-4e34-aece-75047029ed74} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 938, line 939) (in query: SELECT ngramSimHashUTF8([]);) 2025.07.13 02:39:10.309955 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.344585 [ 32979 ] {e7c8e79e-bfbb-4fcb-b509-9cf0108d368f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 1, should be 2: In scope SELECT ngrams([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 939, line 940) (in query: SELECT ngrams([]);) 2025.07.13 02:39:10.354225 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 1, should be 2: In scope SELECT ngrams([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.393851 [ 32979 ] {a5d63a83-0f6c-438b-83c6-c176f5555018} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 940, line 941) (in query: SELECT nonNegativeDerivative([]);) 2025.07.13 02:39:10.400701 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.469855 [ 32979 ] {85d71a29-6311-4ed3-92a3-7b655a1a1667} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL1Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normL1([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 941, line 942) (in query: SELECT normL1([]);) 2025.07.13 02:39:10.476389 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL1Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normL1([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.512101 [ 32979 ] {521392f1-424b-43d7-854e-c81406c15b42} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normL2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 942, line 943) (in query: SELECT normL2([]);) 2025.07.13 02:39:10.518087 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2Norm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normL2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.550195 [ 32979 ] {372a35de-e355-435c-9fd9-dd115a5a7098} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2SquaredNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normL2Squared([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 943, line 944) (in query: SELECT normL2Squared([]);) 2025.07.13 02:39:10.554061 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2SquaredNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normL2Squared([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.593519 [ 32979 ] {2f43daf5-a3a0-4184-aafc-4ea081c014e3} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLinfNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normLinf([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 944, line 945) (in query: SELECT normLinf([]);) 2025.07.13 02:39:10.598673 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLinfNorm has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT normLinf([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.621123 [ 32979 ] {f7dd119b-8925-40af-888f-b362d857d300} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT normLp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 945, line 946) (in query: SELECT normLp([]);) 2025.07.13 02:39:10.624980 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT normLp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.656615 [ 32979 ] {493e49bd-866d-4526-abb0-9ce5effc8674} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Array(Nothing): In scope SELECT normalizeL1([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 946, line 947) (in query: SELECT normalizeL1([]);) 2025.07.13 02:39:10.660556 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Array(Nothing): In scope SELECT normalizeL1([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.684341 [ 32979 ] {98e8a8b1-8ea3-4204-8270-96a383e1a3c0} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Array(Nothing): In scope SELECT normalizeL2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 947, line 948) (in query: SELECT normalizeL2([]);) 2025.07.13 02:39:10.687707 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Array(Nothing): In scope SELECT normalizeL2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.748466 [ 32979 ] {b030d5e0-c2c6-496b-839b-7ce6ee71af64} executeQuery: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Array(Nothing): In scope SELECT normalizeLinf([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 948, line 949) (in query: SELECT normalizeLinf([]);) 2025.07.13 02:39:10.752273 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Array(Nothing): In scope SELECT normalizeLinf([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.772001 [ 32979 ] {8f5fac04-fabe-4e90-aeec-d8d17c973f19} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT normalizeLp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 949, line 950) (in query: SELECT normalizeLp([]);) 2025.07.13 02:39:10.775140 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT normalizeLp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:10.793935 [ 32979 ] {9daa8867-ef21-4974-ba66-e17b2a629819} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeQuery: In scope SELECT normalizeQuery([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 950, line 951) (in query: SELECT normalizeQuery([]);) 2025.07.13 02:39:10.796865 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeQuery: In scope SELECT normalizeQuery([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.901955 [ 32979 ] {279fba94-dcfa-4d2f-b099-8b5e0d54dba3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeQueryKeepNames: In scope SELECT normalizeQueryKeepNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 951, line 952) (in query: SELECT normalizeQueryKeepNames([]);) 2025.07.13 02:39:10.905717 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeQueryKeepNames: In scope SELECT normalizeQueryKeepNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.925031 [ 32979 ] {da22c244-54cf-4bc7-a0de-5cf1ef88c8eb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFC: In scope SELECT normalizeUTF8NFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 952, line 953) (in query: SELECT normalizeUTF8NFC([]);) 2025.07.13 02:39:10.929366 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFC: In scope SELECT normalizeUTF8NFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.948612 [ 32979 ] {90b7884b-73e7-4f3a-8ce3-d477dda7a2e5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFD: In scope SELECT normalizeUTF8NFD([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 953, line 954) (in query: SELECT normalizeUTF8NFD([]);) 2025.07.13 02:39:10.952019 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFD: In scope SELECT normalizeUTF8NFD([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:10.971115 [ 32979 ] {2d7c7599-22ee-41c4-a0c8-a8a0f0af8085} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFKC: In scope SELECT normalizeUTF8NFKC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 954, line 955) (in query: SELECT normalizeUTF8NFKC([]);) 2025.07.13 02:39:10.974736 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFKC: In scope SELECT normalizeUTF8NFKC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.007148 [ 32979 ] {ad9090f0-0cc9-4180-adab-0ee2dbb500af} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFKD: In scope SELECT normalizeUTF8NFKD([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 955, line 956) (in query: SELECT normalizeUTF8NFKD([]);) 2025.07.13 02:39:11.019572 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizeUTF8NFKD: In scope SELECT normalizeUTF8NFKD([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.036724 [ 32979 ] {c1f322f5-f699-4e30-a76e-c349880c5ba3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizedQueryHash: In scope SELECT normalizedQueryHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 956, line 957) (in query: SELECT normalizedQueryHash([]);) 2025.07.13 02:39:11.040095 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizedQueryHash: In scope SELECT normalizedQueryHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.066190 [ 32979 ] {52e656ab-3d1b-4be0-95e5-1ea62c3383a4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizedQueryHashKeepNames: In scope SELECT normalizedQueryHashKeepNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 957, line 958) (in query: SELECT normalizedQueryHashKeepNames([]);) 2025.07.13 02:39:11.078141 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function normalizedQueryHashKeepNames: In scope SELECT normalizedQueryHashKeepNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.095828 [ 32979 ] {864b17eb-726b-41c9-8a2d-bb798b3ef71f} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of argument of function not: In scope SELECT NOT []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 958, line 959) (in query: SELECT not([]);) 2025.07.13 02:39:11.099246 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of argument of function not: In scope SELECT NOT []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.268250 [ 32979 ] {db35aadc-0809-4789-bd3b-40b3cfd0f6e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 1, should be 2: In scope SELECT notEquals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 960, line 961) (in query: SELECT notEquals([]);) 2025.07.13 02:39:11.271895 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 1, should be 2: In scope SELECT notEquals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.290721 [ 32979 ] {56f51c5c-4c7a-48e0-8308-8c5705f8a5fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 1, should be 2: In scope SELECT notILike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 961, line 962) (in query: SELECT notILike([]);) 2025.07.13 02:39:11.294383 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 1, should be 2: In scope SELECT notILike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.318424 [ 32979 ] {85dddfa8-2c79-4070-b81e-c39b1e732c71} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 962, line 963) (in query: SELECT notIn([]);) 2025.07.13 02:39:11.322945 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.346819 [ 32979 ] {347643ef-4934-4f68-aeee-72c90d50d4fc} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 963, line 964) (in query: SELECT notInIgnoreSet([]);) 2025.07.13 02:39:11.350661 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.376870 [ 32979 ] {7fb0f040-180b-4497-90df-e5835a091261} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 1, should be 2: In scope SELECT notLike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 964, line 965) (in query: SELECT notLike([]);) 2025.07.13 02:39:11.381556 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 1, should be 2: In scope SELECT notLike([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.400844 [ 32979 ] {528a0b49-5f3e-4611-beea-20463467bf05} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 965, line 966) (in query: SELECT notNullIn([]);) 2025.07.13 02:39:11.407665 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.428579 [ 32979 ] {9f3082cd-3bec-4c64-b283-e41ac7ed8ad6} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 966, line 967) (in query: SELECT notNullInIgnoreSet([]);) 2025.07.13 02:39:11.432443 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.657954 [ 32979 ] {de0fb094-92a9-4d7a-b88c-93ada880ec48} executeQuery: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT now([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 970, line 971) (in query: SELECT now([]);) 2025.07.13 02:39:11.662778 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT now([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.694476 [ 32979 ] {1cb974f5-03d0-4aa8-901a-897e0532784a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 0 argument of function now64. Expected const integer.: In scope SELECT now64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 971, line 972) (in query: SELECT now64([]);) 2025.07.13 02:39:11.702652 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 0 argument of function now64. Expected const integer.: In scope SELECT now64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.731651 [ 32979 ] {25d7fba7-1b94-4eff-9f96-7bc56a2067af} executeQuery: Code: 43. DB::Exception: Arguments of function nowInBlock should be String or FixedString: In scope SELECT nowInBlock([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 972, line 973) (in query: SELECT nowInBlock([]);) 2025.07.13 02:39:11.739229 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function nowInBlock should be String or FixedString: In scope SELECT nowInBlock([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:11.774883 [ 32979 ] {fd92b807-c757-4825-b58d-0bcc4078d8e7} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 973, line 974) (in query: SELECT nth_value([]);) 2025.07.13 02:39:11.779410 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.895580 [ 32979 ] {f2763b83-da6a-4aa7-92f6-70bc3ef2797e} executeQuery: Code: 36. DB::Exception: 'ntile' argument type must be an unsigned integer (not larger than 64-bit), got Array(Nothing). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 974, line 975) (in query: SELECT ntile([]);) 2025.07.13 02:39:11.901223 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: 'ntile' argument type must be an unsigned integer (not larger than 64-bit), got Array(Nothing). (BAD_ARGUMENTS) 2025.07.13 02:39:11.939872 [ 32979 ] {4eca05e6-1feb-44ac-a625-c9e70463ba15} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 1, should be 2: In scope SELECT nullIf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 975, line 976) (in query: SELECT nullIf([]);) 2025.07.13 02:39:11.944585 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 1, should be 2: In scope SELECT nullIf([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:11.966515 [ 32979 ] {0d098cf3-3b48-42d6-84e2-8e7394aa5683} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 976, line 977) (in query: SELECT nullIn([]);) 2025.07.13 02:39:11.971084 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:12.030468 [ 32979 ] {4e830357-e832-469c-9c8f-ca3790975ca8} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 977, line 978) (in query: SELECT nullInIgnoreSet([]);) 2025.07.13 02:39:12.034692 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:12.062650 [ 32979 ] {2020a217-24c2-4c67-9d71-a27a21024361} executeQuery: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 1: In scope SELECT or([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 978, line 979) (in query: SELECT or([]);) 2025.07.13 02:39:12.067234 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 1: In scope SELECT or([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:12.090938 [ 32979 ] {e011bd02-5bb1-47c0-be23-9508eed33aca} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlay([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 979, line 980) (in query: SELECT overlay([]);) 2025.07.13 02:39:12.095420 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlay([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:12.116619 [ 32979 ] {b51eda74-e46c-4f4f-bfc9-9e346982600f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlayUTF8'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlayUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 980, line 981) (in query: SELECT overlayUTF8([]);) 2025.07.13 02:39:12.120078 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlayUTF8'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlayUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:12.139595 [ 32979 ] {c471fdfc-2b24-46b7-b5ee-0fe0c9990e96} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 981, line 982) (in query: SELECT parseDateTime([]);) 2025.07.13 02:39:12.142974 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.163333 [ 32979 ] {07cf4018-8486-433e-9076-c817dfe300af} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffort: In scope SELECT parseDateTime32BestEffort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 982, line 983) (in query: SELECT parseDateTime32BestEffort([]);) 2025.07.13 02:39:12.175857 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffort: In scope SELECT parseDateTime32BestEffort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.196040 [ 32979 ] {f6a6a3ad-404c-41b1-a30f-dfac8325e242} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 983, line 984) (in query: SELECT parseDateTime32BestEffortOrNull([]);) 2025.07.13 02:39:12.199279 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.223071 [ 32979 ] {ab3125e3-2864-42ab-b1ea-d0ffe585245b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 984, line 985) (in query: SELECT parseDateTime32BestEffortOrZero([]);) 2025.07.13 02:39:12.227422 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.246460 [ 32979 ] {6f9b940a-c5d5-41aa-bd2c-f64e065dad2e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 985, line 986) (in query: SELECT parseDateTime64([]);) 2025.07.13 02:39:12.249516 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.268758 [ 32979 ] {8db242b1-0ed4-4552-9e01-2dc3d2554da6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 986, line 987) (in query: SELECT parseDateTime64BestEffort([]);) 2025.07.13 02:39:12.272502 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.302806 [ 32979 ] {52254245-65c8-43d6-bc04-ad1549313804} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 987, line 988) (in query: SELECT parseDateTime64BestEffortOrNull([]);) 2025.07.13 02:39:12.306901 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.344540 [ 32979 ] {562436cf-3f4a-449d-95b0-9f4cd8928467} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 988, line 989) (in query: SELECT parseDateTime64BestEffortOrZero([]);) 2025.07.13 02:39:12.347670 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.376237 [ 32979 ] {357d99c0-b98c-49a9-aa19-3539d98196d6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUS([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 989, line 990) (in query: SELECT parseDateTime64BestEffortUS([]);) 2025.07.13 02:39:12.380391 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUS([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.412635 [ 32979 ] {70199df3-e2a5-44e2-8d42-ffbdacea9982} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 990, line 991) (in query: SELECT parseDateTime64BestEffortUSOrNull([]);) 2025.07.13 02:39:12.416833 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.436014 [ 32979 ] {e5ef0c14-e42f-49e4-bcc2-0f2aa1328ee8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 991, line 992) (in query: SELECT parseDateTime64BestEffortUSOrZero([]);) 2025.07.13 02:39:12.439090 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.457805 [ 32979 ] {7e88837d-93b2-42c6-aa52-5b1aa81a440d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntax([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 992, line 993) (in query: SELECT parseDateTime64InJodaSyntax([]);) 2025.07.13 02:39:12.461142 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntax([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.562594 [ 32979 ] {6bfa0a5b-3d3b-4b93-b0a3-75f909803f2e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 993, line 994) (in query: SELECT parseDateTime64InJodaSyntaxOrNull([]);) 2025.07.13 02:39:12.566327 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.592010 [ 32979 ] {edd89b7a-857f-46b6-8819-e839710e21a8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 994, line 995) (in query: SELECT parseDateTime64InJodaSyntaxOrZero([]);) 2025.07.13 02:39:12.597147 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.627525 [ 32979 ] {3d35ec0f-0053-473a-a897-f4d513c7a1ce} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 995, line 996) (in query: SELECT parseDateTime64OrNull([]);) 2025.07.13 02:39:12.633866 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.671289 [ 32979 ] {b0daabb2-59dc-4c03-93e0-0511509e9837} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 996, line 997) (in query: SELECT parseDateTime64OrZero([]);) 2025.07.13 02:39:12.675898 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.713979 [ 32979 ] {2e4bb381-f453-460a-89a4-e4ef78595261} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffort: In scope SELECT parseDateTimeBestEffort([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 997, line 998) (in query: SELECT parseDateTimeBestEffort([]);) 2025.07.13 02:39:12.719375 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffort: In scope SELECT parseDateTimeBestEffort([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.751888 [ 32979 ] {e541050f-1e18-42c9-9620-3d118beb7086} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 998, line 999) (in query: SELECT parseDateTimeBestEffortOrNull([]);) 2025.07.13 02:39:12.759015 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.789058 [ 32979 ] {df4a8b63-d23e-4a73-9049-f85bd8d129ae} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 999, line 1000) (in query: SELECT parseDateTimeBestEffortOrZero([]);) 2025.07.13 02:39:12.801564 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.841186 [ 32979 ] {9c6f8d3a-4591-46b0-9812-d28e42811326} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUS: In scope SELECT parseDateTimeBestEffortUS([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1000, line 1001) (in query: SELECT parseDateTimeBestEffortUS([]);) 2025.07.13 02:39:12.846218 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUS: In scope SELECT parseDateTimeBestEffortUS([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.876382 [ 32979 ] {424226dc-ea08-466e-ace5-d9a711049ce0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1001, line 1002) (in query: SELECT parseDateTimeBestEffortUSOrNull([]);) 2025.07.13 02:39:12.885090 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:12.934696 [ 32979 ] {0e2d6c5b-17fa-4662-a869-7c30c03b6a42} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1002, line 1003) (in query: SELECT parseDateTimeBestEffortUSOrZero([]);) 2025.07.13 02:39:13.006762 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.045452 [ 32979 ] {ed7cf045-2acf-44ad-be9e-9cf5e7600eed} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntax([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1003, line 1004) (in query: SELECT parseDateTimeInJodaSyntax([]);) 2025.07.13 02:39:13.051605 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntax([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.077378 [ 32979 ] {5d3d7d70-3d09-423b-9c08-195a5b7426a1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1004, line 1005) (in query: SELECT parseDateTimeInJodaSyntaxOrNull([]);) 2025.07.13 02:39:13.083486 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.116001 [ 32979 ] {32f1b80f-2627-4657-bfe0-821d48a0ff0a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1005, line 1006) (in query: SELECT parseDateTimeInJodaSyntaxOrZero([]);) 2025.07.13 02:39:13.122267 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.196617 [ 32979 ] {8826093f-12c9-425f-ae89-63b848c427de} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1006, line 1007) (in query: SELECT parseDateTimeOrNull([]);) 2025.07.13 02:39:13.199560 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.224029 [ 32979 ] {7982a282-031a-4a5a-8e25-2a434b39e78d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1007, line 1008) (in query: SELECT parseDateTimeOrZero([]);) 2025.07.13 02:39:13.229444 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.273861 [ 32979 ] {04f9c70f-190f-4dfc-af4f-172b33e33cce} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: Array(Nothing): In scope SELECT parseReadableSize([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1008, line 1009) (in query: SELECT parseReadableSize([]);) 2025.07.13 02:39:13.278955 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: Array(Nothing): In scope SELECT parseReadableSize([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.306237 [ 32979 ] {2c432069-9533-4d38-a222-560140c5f701} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseReadableSizeOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1009, line 1010) (in query: SELECT parseReadableSizeOrNull([]);) 2025.07.13 02:39:13.332673 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseReadableSizeOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.375442 [ 32979 ] {46f90515-23dd-435c-b7eb-c7fca02bc4ea} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseReadableSizeOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1010, line 1011) (in query: SELECT parseReadableSizeOrZero([]);) 2025.07.13 02:39:13.386214 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseReadableSizeOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.524111 [ 32979 ] {2e433a13-59f5-4d2d-9b36-c18ffd5150fa} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) as time string.: In scope SELECT parseTimeDelta([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1011, line 1012) (in query: SELECT parseTimeDelta([]);) 2025.07.13 02:39:13.537194 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) as time string.: In scope SELECT parseTimeDelta([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.728011 [ 32979 ] {400e8e38-daac-4bb2-85bd-1c4e84d98978} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function path: In scope SELECT path([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1014, line 1015) (in query: SELECT path([]);) 2025.07.13 02:39:13.732356 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function path: In scope SELECT path([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.757492 [ 32979 ] {bf978e72-a05b-4b21-b5cf-7eda47d1206f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function pathFull: In scope SELECT pathFull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1015, line 1016) (in query: SELECT pathFull([]);) 2025.07.13 02:39:13.760917 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function pathFull: In scope SELECT pathFull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:13.818637 [ 32979 ] {ba0781f1-7e3c-4e86-abbe-ea6636a9a00d} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1016, line 1017) (in query: SELECT percentRank([]);) 2025.07.13 02:39:13.821299 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:39:13.868126 [ 32979 ] {2884ffaf-3a14-4f9c-9f57-81e0378b0b2c} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1017, line 1018) (in query: SELECT percent_rank([]);) 2025.07.13 02:39:13.872733 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:39:13.894270 [ 32979 ] {25b7c4db-3030-4bb2-80d2-65d1e7ae033d} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 1, should be 0: In scope SELECT pi([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1018, line 1019) (in query: SELECT pi([]);) 2025.07.13 02:39:13.898901 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 1, should be 0: In scope SELECT pi([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:13.923004 [ 32979 ] {39e4a849-7e76-4438-8995-19bfc2348967} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT plus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1019, line 1020) (in query: SELECT plus([]);) 2025.07.13 02:39:13.932612 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT plus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:13.965318 [ 32979 ] {8fa0bb3a-93be-4383-8ab9-5b514eb4cd9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT pmod([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1020, line 1021) (in query: SELECT pmod([]);) 2025.07.13 02:39:13.980689 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT pmod([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.019147 [ 32979 ] {d83f0c2c-dc77-490b-a759-1877f2b97f1c} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1021, line 1022) (in query: SELECT pointInEllipses([]);) 2025.07.13 02:39:14.024892 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.044264 [ 32979 ] {6163e88b-fecb-452c-983b-031b8c6bdf48} executeQuery: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1022, line 1023) (in query: SELECT pointInPolygon([]);) 2025.07.13 02:39:14.048227 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:14.096067 [ 32979 ] {5c39a9f5-9391-4938-a7b9-7648020a4e0c} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1023, line 1024) (in query: SELECT polygonAreaCartesian([]);) 2025.07.13 02:39:14.101611 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS) 2025.07.13 02:39:14.138428 [ 32979 ] {b1755948-6382-48b2-980b-0d306c8c619a} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaSpherical([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1024, line 1025) (in query: SELECT polygonAreaSpherical([]);) 2025.07.13 02:39:14.142792 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaSpherical([]). (BAD_ARGUMENTS) 2025.07.13 02:39:14.182255 [ 32979 ] {89672efb-df2d-4a4d-9bff-a2bc9e3fb2d7} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonConvexHullCartesian([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1025, line 1026) (in query: SELECT polygonConvexHullCartesian([]);) 2025.07.13 02:39:14.190190 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonConvexHullCartesian([]). (BAD_ARGUMENTS) 2025.07.13 02:39:14.217802 [ 32979 ] {8b53c1a4-d4a6-4653-9fcd-7ec9c0dfea9a} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonPerimeterCartesian([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1026, line 1027) (in query: SELECT polygonPerimeterCartesian([]);) 2025.07.13 02:39:14.221044 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonPerimeterCartesian([]). (BAD_ARGUMENTS) 2025.07.13 02:39:14.243400 [ 32979 ] {0766fb8e-a986-47e2-9a4e-68da48848ccf} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonPerimeterSpherical([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1027, line 1028) (in query: SELECT polygonPerimeterSpherical([]);) 2025.07.13 02:39:14.251876 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonPerimeterSpherical([]). (BAD_ARGUMENTS) 2025.07.13 02:39:14.269625 [ 32979 ] {55a27541-1b9d-4038-9875-4a13cf0a9208} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1028, line 1029) (in query: SELECT polygonsDistanceCartesian([]);) 2025.07.13 02:39:14.275570 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.301018 [ 32979 ] {c0e99e0d-138c-4b53-b055-86f09e1d1b0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1029, line 1030) (in query: SELECT polygonsDistanceSpherical([]);) 2025.07.13 02:39:14.304024 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.320197 [ 32979 ] {06a1dcdf-1b83-40e5-aa9c-6d94d056eac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsEqualsCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1030, line 1031) (in query: SELECT polygonsEqualsCartesian([]);) 2025.07.13 02:39:14.323199 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsEqualsCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.345461 [ 32979 ] {d8660285-e5f9-462b-b048-5387cf28e860} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1031, line 1032) (in query: SELECT polygonsIntersectionCartesian([]);) 2025.07.13 02:39:14.352564 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.372379 [ 32979 ] {05642cf8-0c9b-4b93-b84b-78e847830a5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1032, line 1033) (in query: SELECT polygonsIntersectionSpherical([]);) 2025.07.13 02:39:14.386502 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.424539 [ 32979 ] {4399be03-9139-44d2-b496-240f0c77d84b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1033, line 1034) (in query: SELECT polygonsSymDifferenceCartesian([]);) 2025.07.13 02:39:14.427404 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.450681 [ 32979 ] {69d486ec-6dc6-4a49-b500-4419e7648ef6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1034, line 1035) (in query: SELECT polygonsSymDifferenceSpherical([]);) 2025.07.13 02:39:14.453382 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.507247 [ 32979 ] {fc73780c-5bfe-4fb7-92b7-cbe86351a24d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1035, line 1036) (in query: SELECT polygonsUnionCartesian([]);) 2025.07.13 02:39:14.510332 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.609614 [ 32979 ] {7e469237-d8ca-4002-abd3-089a7d0816d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1036, line 1037) (in query: SELECT polygonsUnionSpherical([]);) 2025.07.13 02:39:14.617196 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.658451 [ 32979 ] {10b57d9e-107a-451f-85f3-aa397f5791d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1037, line 1038) (in query: SELECT polygonsWithinCartesian([]);) 2025.07.13 02:39:14.662428 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinCartesian([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.704797 [ 32979 ] {fcef4ff8-ef18-455b-b248-6b593601ca6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1038, line 1039) (in query: SELECT polygonsWithinSpherical([]);) 2025.07.13 02:39:14.711742 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinSpherical([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.781920 [ 32979 ] {d4be93de-c7bd-4561-95bc-83a9ade08b74} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function port. Must be String.: In scope SELECT port([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1039, line 1040) (in query: SELECT port([]);) 2025.07.13 02:39:14.787723 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function port. Must be String.: In scope SELECT port([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:14.821349 [ 32979 ] {9cca8fd6-2273-47a1-a08c-6c0ce888a8b0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function portRFC. Must be String.: In scope SELECT portRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1040, line 1041) (in query: SELECT portRFC([]);) 2025.07.13 02:39:14.826551 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function portRFC. Must be String.: In scope SELECT portRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:14.848036 [ 32979 ] {0407db5b-624b-4e73-8fa7-ab5da6902c9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1041, line 1043) (in query: SELECT positionCaseInsensitive([]);) 2025.07.13 02:39:14.860283 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitive([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.906042 [ 32979 ] {823a5665-3fae-463b-bf7c-46b41e950f24} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1042, line 1044) (in query: SELECT positionCaseInsensitiveUTF8([]);) 2025.07.13 02:39:14.910176 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:14.999521 [ 32979 ] {7d6faaa7-142e-4e9e-9756-e1b33cd19429} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1043, line 1045) (in query: SELECT positionUTF8([]);) 2025.07.13 02:39:15.014400 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:15.042280 [ 32979 ] {0ec1e320-439a-4eef-b51a-c6005d19f4c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positiveModulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1044, line 1046) (in query: SELECT positiveModulo([]);) 2025.07.13 02:39:15.046923 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positiveModulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:15.073583 [ 32979 ] {fda46e19-63e0-4648-bf8a-9555b61067d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positive_modulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1045, line 1047) (in query: SELECT positive_modulo([]);) 2025.07.13 02:39:15.084430 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positive_modulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:15.141389 [ 32979 ] {5099bf76-ae3a-4287-84d1-364d6695f962} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT pow([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1046, line 1048) (in query: SELECT pow([]);) 2025.07.13 02:39:15.144322 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT pow([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:15.211383 [ 32979 ] {0c39b682-df2b-4e70-849b-915addfdcd69} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT power([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1047, line 1049) (in query: SELECT power([]);) 2025.07.13 02:39:15.221609 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT power([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:15.246581 [ 32979 ] {bf229e3f-20ae-4136-ac80-b705f2c09f81} executeQuery: Code: 43. DB::Exception: The first argument type of function printf is Array(Nothing), but String type is expected: In scope SELECT printf([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1048, line 1050) (in query: SELECT printf([]);) 2025.07.13 02:39:15.249972 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The first argument type of function printf is Array(Nothing), but String type is expected: In scope SELECT printf([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.287119 [ 32979 ] {c4ec8fc6-dfef-4c56-bcf7-83773de557c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 1, should be 6: In scope SELECT proportionsZTest([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1049, line 1051) (in query: SELECT proportionsZTest([]);) 2025.07.13 02:39:15.293102 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 1, should be 6: In scope SELECT proportionsZTest([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:15.337192 [ 32979 ] {88ee7942-ff2b-4ccc-bd9e-95fc10147bc6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function protocol: In scope SELECT protocol([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1050, line 1052) (in query: SELECT protocol([]);) 2025.07.13 02:39:15.342048 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function protocol: In scope SELECT protocol([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.371886 [ 32979 ] {72d0dc54-7328-4571-88e2-8a28692c1125} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function punycodeDecode: In scope SELECT punycodeDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1051, line 1053) (in query: SELECT punycodeDecode([]);) 2025.07.13 02:39:15.381984 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function punycodeDecode: In scope SELECT punycodeDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.417223 [ 32979 ] {1f85fe0f-6a93-493c-8d1b-495690e0daa1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function punycodeEncode: In scope SELECT punycodeEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1052, line 1054) (in query: SELECT punycodeEncode([]);) 2025.07.13 02:39:15.433169 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function punycodeEncode: In scope SELECT punycodeEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.483713 [ 32979 ] {c4dc74d7-d7df-430a-b0c3-548d50646d26} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1053, line 1055) (in query: SELECT quantile([]);) 2025.07.13 02:39:15.488984 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.525082 [ 32979 ] {045d7093-5efa-47ac-8bee-3fac3f4f528e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1054, line 1056) (in query: SELECT quantileBFloat16([]);) 2025.07.13 02:39:15.533516 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.632932 [ 32979 ] {1760ad26-072f-42d1-aa3d-94082b217826} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1055, line 1057) (in query: SELECT quantileBFloat16Weighted([]);) 2025.07.13 02:39:15.638505 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.758306 [ 32979 ] {d0f03569-79bc-413b-8a48-1166f388746e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1056, line 1058) (in query: SELECT quantileDD([]);) 2025.07.13 02:39:15.763792 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.794780 [ 32979 ] {e089c1a8-dbc5-4037-b7ce-55ed16ccc044} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1057, line 1059) (in query: SELECT quantileDeterministic([]);) 2025.07.13 02:39:15.800128 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.829998 [ 32979 ] {3faa79b8-4bb4-474d-852d-f225250e64cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1058, line 1060) (in query: SELECT quantileExact([]);) 2025.07.13 02:39:15.835660 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.867308 [ 32979 ] {736738b3-4eed-4d40-b895-797afaa7c78a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1059, line 1061) (in query: SELECT quantileExactExclusive([]);) 2025.07.13 02:39:15.873165 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:15.904224 [ 32979 ] {10763643-f53b-4220-b2b8-7126b45fde29} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1060, line 1062) (in query: SELECT quantileExactHigh([]);) 2025.07.13 02:39:15.916032 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.068087 [ 32979 ] {08748ef8-678a-4073-939c-1070c2f1b03d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1061, line 1063) (in query: SELECT quantileExactInclusive([]);) 2025.07.13 02:39:16.079050 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.112602 [ 32979 ] {709bd916-3923-4ddf-a1d0-934793a3d8aa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1062, line 1064) (in query: SELECT quantileExactLow([]);) 2025.07.13 02:39:16.115603 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.198686 [ 32979 ] {2ca465e0-00a6-428f-87fc-669f86fb3fbc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1063, line 1065) (in query: SELECT quantileExactWeighted([]);) 2025.07.13 02:39:16.238733 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.318552 [ 32979 ] {f873ddf6-178e-4bbc-8126-d4b00d0d7798} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1064, line 1066) (in query: SELECT quantileExactWeightedInterpolated([]);) 2025.07.13 02:39:16.326202 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.380408 [ 32979 ] {17f3b1a6-4b80-4b01-a52b-5e96a75ba5e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1065, line 1067) (in query: SELECT quantileGK([]);) 2025.07.13 02:39:16.389097 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.435115 [ 32979 ] {f0907d18-e6c4-4008-ac9a-35a500630c72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1066, line 1068) (in query: SELECT quantileInterpolatedWeighted([]);) 2025.07.13 02:39:16.444513 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.556136 [ 32979 ] {85f8a10b-19db-4e9c-a2df-24393997f651} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1067, line 1069) (in query: SELECT quantileTDigest([]);) 2025.07.13 02:39:16.562374 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.598512 [ 32979 ] {d456fc28-293e-4b7e-a0ba-6b8ce2f1388d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1068, line 1070) (in query: SELECT quantileTDigestWeighted([]);) 2025.07.13 02:39:16.601218 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.626898 [ 32979 ] {2fd93377-b938-4dc4-8ce7-0d964b9d1787} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1069, line 1071) (in query: SELECT quantileTiming([]);) 2025.07.13 02:39:16.631501 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.676032 [ 32979 ] {5856dfe8-caf6-430a-97e7-48ced3a3a555} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1070, line 1072) (in query: SELECT quantileTimingWeighted([]);) 2025.07.13 02:39:16.680909 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.707869 [ 32979 ] {a83216f7-ca21-4404-ba14-9835517f52fd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1071, line 1073) (in query: SELECT quantiles([]);) 2025.07.13 02:39:16.712869 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.759635 [ 32979 ] {7520349d-ad94-40aa-96f9-fe3446eec519} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1072, line 1074) (in query: SELECT quantilesBFloat16([]);) 2025.07.13 02:39:16.771877 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.812507 [ 32979 ] {a8561a9b-8f37-42f8-9726-8eac681be71b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1073, line 1075) (in query: SELECT quantilesBFloat16Weighted([]);) 2025.07.13 02:39:16.821685 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.879171 [ 32979 ] {d2803aeb-1ba5-4106-af11-3c5bca7d296c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1074, line 1076) (in query: SELECT quantilesDD([]);) 2025.07.13 02:39:16.906485 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:16.955654 [ 32979 ] {205bd8b7-ccd6-4e88-ba99-fac3d32bbb1a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1075, line 1077) (in query: SELECT quantilesDeterministic([]);) 2025.07.13 02:39:16.961841 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.123306 [ 32979 ] {0da8ea4a-ec1f-45d4-93d7-f6a174caf08b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1076, line 1078) (in query: SELECT quantilesExact([]);) 2025.07.13 02:39:17.126728 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.174624 [ 32979 ] {e874dbc3-0ee9-46ce-8c39-acfcbf0828cc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1077, line 1079) (in query: SELECT quantilesExactExclusive([]);) 2025.07.13 02:39:17.179590 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.213823 [ 32979 ] {572006ca-6aed-4c99-aa6a-638c72ed9022} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1078, line 1080) (in query: SELECT quantilesExactHigh([]);) 2025.07.13 02:39:17.218933 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.245349 [ 32979 ] {08ded42a-4cb6-465f-ab92-952adceb0424} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1079, line 1081) (in query: SELECT quantilesExactInclusive([]);) 2025.07.13 02:39:17.255004 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.338671 [ 32979 ] {e817b1e6-63be-4867-b168-e78f51f5a826} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1080, line 1082) (in query: SELECT quantilesExactLow([]);) 2025.07.13 02:39:17.346525 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.390611 [ 32979 ] {a2cff69a-a69a-47ee-a95a-05d05a78788b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1081, line 1083) (in query: SELECT quantilesExactWeighted([]);) 2025.07.13 02:39:17.395127 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.426407 [ 32979 ] {6de18667-fa59-4ae0-9341-47accaaf5e05} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeightedInterpolated([]);) 2025.07.13 02:39:17.433155 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.498141 [ 32979 ] {f943ed60-e9e4-4996-9ca6-607d9de9f483} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1083, line 1085) (in query: SELECT quantilesGK([]);) 2025.07.13 02:39:17.505604 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.566814 [ 32979 ] {0ec1a2a4-1761-44d2-a62e-0214161b3694} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1084, line 1086) (in query: SELECT quantilesInterpolatedWeighted([]);) 2025.07.13 02:39:17.570251 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.585527 [ 32979 ] {bd2f486f-ddcd-4d10-ae51-1461f4513dfa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1085, line 1087) (in query: SELECT quantilesTDigest([]);) 2025.07.13 02:39:17.587885 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.669428 [ 32979 ] {7a2beb9c-a710-4e54-8bae-eb194b196f77} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigestWeighted([]);) 2025.07.13 02:39:17.674971 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.708043 [ 32979 ] {5b660f2f-cff7-494b-8706-bea458945cb1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1087, line 1089) (in query: SELECT quantilesTiming([]);) 2025.07.13 02:39:17.715149 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.774692 [ 32979 ] {e8812765-c929-4cba-a2c3-d490913d6f83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1088, line 1090) (in query: SELECT quantilesTimingWeighted([]);) 2025.07.13 02:39:17.780866 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.819973 [ 32979 ] {768dbeab-fe4f-4967-b726-9b4489578e0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT queryID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1089, line 1091) (in query: SELECT queryID([]);) 2025.07.13 02:39:17.824168 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT queryID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:17.857755 [ 32979 ] {2eeeb522-1e36-439b-b093-8c17eed1f7cf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function queryString: In scope SELECT queryString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1090, line 1092) (in query: SELECT queryString([]);) 2025.07.13 02:39:17.867643 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function queryString: In scope SELECT queryString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.911383 [ 32979 ] {744d7ddb-15cf-4a31-9654-1210f5998428} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function queryStringAndFragment: In scope SELECT queryStringAndFragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1091, line 1093) (in query: SELECT queryStringAndFragment([]);) 2025.07.13 02:39:17.916653 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function queryStringAndFragment: In scope SELECT queryStringAndFragment([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:17.963083 [ 32979 ] {6fcaded3-e881-47e1-bc54-eed0e79c43e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT query_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1092, line 1094) (in query: SELECT query_id([]);) 2025.07.13 02:39:18.029317 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT query_id([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:18.061101 [ 32979 ] {3691861d-e82c-4b92-a7f4-a6a07f9576e8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function radians: In scope SELECT radians([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1093, line 1095) (in query: SELECT radians([]);) 2025.07.13 02:39:18.066342 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function radians: In scope SELECT radians([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:18.425413 [ 32979 ] {466c2d69-6583-4409-bbf2-b00aa0a06567} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBernoulli, expected Float64 or integer: In scope SELECT randBernoulli([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1097, line 1099) (in query: SELECT randBernoulli([]);) 2025.07.13 02:39:18.430224 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBernoulli, expected Float64 or integer: In scope SELECT randBernoulli([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:18.460435 [ 32979 ] {52704fca-9d90-4cf2-8a10-5cc8b2651d63} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1098, line 1100) (in query: SELECT randBinomial([]);) 2025.07.13 02:39:18.465566 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:18.582121 [ 32979 ] {a1bcdb96-e5d0-4841-8b4c-91eff8060d45} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randChiSquared, expected Float64 or integer: In scope SELECT randChiSquared([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1100, line 1102) (in query: SELECT randChiSquared([]);) 2025.07.13 02:39:18.587615 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randChiSquared, expected Float64 or integer: In scope SELECT randChiSquared([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:18.731189 [ 32979 ] {c4d808c7-df2b-409f-b98e-49437f3add11} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randExponential, expected Float64 or integer: In scope SELECT randExponential([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1102, line 1104) (in query: SELECT randExponential([]);) 2025.07.13 02:39:18.737078 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randExponential, expected Float64 or integer: In scope SELECT randExponential([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:18.774882 [ 32979 ] {400717e7-4311-4928-85aa-0b3848ee1800} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1103, line 1105) (in query: SELECT randFisherF([]);) 2025.07.13 02:39:18.780429 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:18.909154 [ 32979 ] {44a004f7-e278-409b-9d8d-1d3167e90885} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1104, line 1106) (in query: SELECT randLogNormal([]);) 2025.07.13 02:39:18.913827 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:18.959415 [ 32979 ] {31cb0fc6-48de-4244-b7c5-ce3ed9eeb66e} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1105, line 1107) (in query: SELECT randNegativeBinomial([]);) 2025.07.13 02:39:18.963849 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:18.987063 [ 32979 ] {d8527f2b-2496-4b1f-a4a9-2455a2a51961} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1106, line 1108) (in query: SELECT randNormal([]);) 2025.07.13 02:39:18.989894 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:19.010315 [ 32979 ] {6eb33cf1-04d6-445d-9193-107d4f5a944d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randPoisson, expected Float64 or integer: In scope SELECT randPoisson([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1107, line 1109) (in query: SELECT randPoisson([]);) 2025.07.13 02:39:19.014821 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randPoisson, expected Float64 or integer: In scope SELECT randPoisson([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.047959 [ 32979 ] {e1b7f052-6e20-4151-b1c2-f81eb503d722} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randStudentT, expected Float64 or integer: In scope SELECT randStudentT([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1108, line 1110) (in query: SELECT randStudentT([]);) 2025.07.13 02:39:19.050995 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randStudentT, expected Float64 or integer: In scope SELECT randStudentT([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.107452 [ 32979 ] {050b228e-35d7-448b-bf33-9771d1eac3a8} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1109, line 1111) (in query: SELECT randUniform([]);) 2025.07.13 02:39:19.110491 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:19.133681 [ 32979 ] {8e78a78e-91b7-40e9-a70e-b6e0996cfc96} executeQuery: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1110, line 1112) (in query: SELECT randomFixedString([]);) 2025.07.13 02:39:19.136578 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.152411 [ 32979 ] {bd8e2996-27c1-46c6-a273-c4e52710a62c} executeQuery: Code: 43. DB::Exception: First argument of function randomPrintableASCII must have numeric type: In scope SELECT randomPrintableASCII([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1111, line 1113) (in query: SELECT randomPrintableASCII([]);) 2025.07.13 02:39:19.158156 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function randomPrintableASCII must have numeric type: In scope SELECT randomPrintableASCII([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.193560 [ 32979 ] {68fbc597-d299-4842-af59-eafb36213181} executeQuery: Code: 43. DB::Exception: First argument of function randomString must have numeric type: In scope SELECT randomString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1112, line 1114) (in query: SELECT randomString([]);) 2025.07.13 02:39:19.198369 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function randomString must have numeric type: In scope SELECT randomString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.294127 [ 32979 ] {452dc042-6502-4345-9530-0a12e007a3e9} executeQuery: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1113, line 1115) (in query: SELECT randomStringUTF8([]);) 2025.07.13 02:39:19.300317 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.331636 [ 32979 ] {29db8972-9f52-4481-8afa-db24916d726a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function range: In scope SELECT range([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1114, line 1116) (in query: SELECT range([]);) 2025.07.13 02:39:19.337564 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function range: In scope SELECT range([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.391568 [ 32979 ] {57b92528-ec56-44a6-accb-9334b2108531} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1115, line 1117) (in query: SELECT rank([]);) 2025.07.13 02:39:19.395745 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:39:19.420884 [ 32979 ] {b6420f21-dc89-423a-b7ed-654e1eb7f9ce} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1116, line 1118) (in query: SELECT rankCorr([]);) 2025.07.13 02:39:19.425737 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:19.468873 [ 32979 ] {946675fb-911e-4076-a464-45ee2514bd8b} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTLineString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1117, line 1119) (in query: SELECT readWKTLineString([]);) 2025.07.13 02:39:19.473636 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTLineString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.502380 [ 32979 ] {e39294e3-3d6e-4c2a-8544-73fa194d8864} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiLineString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1118, line 1120) (in query: SELECT readWKTMultiLineString([]);) 2025.07.13 02:39:19.507283 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiLineString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.537806 [ 32979 ] {e1fdab1e-d667-4a34-8bb7-91772ca9c3c8} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiPolygon([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiPolygon([]);) 2025.07.13 02:39:19.542444 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiPolygon([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.570589 [ 32979 ] {f183017e-4ee3-42ae-a54e-9ab88b92964a} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPoint([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1120, line 1122) (in query: SELECT readWKTPoint([]);) 2025.07.13 02:39:19.575613 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPoint([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.604638 [ 32979 ] {2d0b5088-f855-40d4-b33b-52d03b84bbab} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPolygon([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1121, line 1123) (in query: SELECT readWKTPolygon([]);) 2025.07.13 02:39:19.609546 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPolygon([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.641413 [ 32979 ] {03997c44-e831-409e-a2ba-8cc8d00dfdad} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTRing([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1122, line 1124) (in query: SELECT readWKTRing([]);) 2025.07.13 02:39:19.647895 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTRing([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.677094 [ 32979 ] {49c31062-0a1a-4fc9-ba2b-8d12af367e8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1123, line 1125) (in query: SELECT regexpExtract([]);) 2025.07.13 02:39:19.682559 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:19.716262 [ 32979 ] {0cf89399-bebd-4002-a469-3666ed1cef28} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1 argument of function regexpQuoteMeta. Must be String.: In scope SELECT regexpQuoteMeta([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1124, line 1126) (in query: SELECT regexpQuoteMeta([]);) 2025.07.13 02:39:19.721821 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1 argument of function regexpQuoteMeta. Must be String.: In scope SELECT regexpQuoteMeta([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.763840 [ 32979 ] {714661e7-3906-41de-b303-fcf05a833771} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionHierarchy (must be UInt32): In scope SELECT regionHierarchy([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1125, line 1127) (in query: SELECT regionHierarchy([]);) 2025.07.13 02:39:19.770025 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionHierarchy (must be UInt32): In scope SELECT regionHierarchy([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.815308 [ 32979 ] {6125217d-f923-4135-b0ba-c28969854e81} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 1, should be 2 or 3.: In scope SELECT regionIn([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1126, line 1128) (in query: SELECT regionIn([]);) 2025.07.13 02:39:19.820772 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 1, should be 2 or 3.: In scope SELECT regionIn([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:19.949199 [ 32979 ] {32da4ade-962c-41e9-a965-296ba80214c8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToArea (must be UInt32): In scope SELECT regionToArea([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1127, line 1129) (in query: SELECT regionToArea([]);) 2025.07.13 02:39:19.954789 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToArea (must be UInt32): In scope SELECT regionToArea([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:19.985402 [ 32979 ] {508b484f-2b5a-4a20-a6c2-779fd893b10f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCity (must be UInt32): In scope SELECT regionToCity([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1128, line 1130) (in query: SELECT regionToCity([]);) 2025.07.13 02:39:19.991287 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCity (must be UInt32): In scope SELECT regionToCity([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.064150 [ 32979 ] {e4c77c8f-e452-40d9-9650-b05f4e4bae85} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToContinent (must be UInt32): In scope SELECT regionToContinent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1129, line 1131) (in query: SELECT regionToContinent([]);) 2025.07.13 02:39:20.069044 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToContinent (must be UInt32): In scope SELECT regionToContinent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.125450 [ 32979 ] {eb4c499d-ab02-4e15-9794-fcedbd21b2db} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCountry (must be UInt32): In scope SELECT regionToCountry([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1130, line 1132) (in query: SELECT regionToCountry([]);) 2025.07.13 02:39:20.133644 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCountry (must be UInt32): In scope SELECT regionToCountry([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.296575 [ 32979 ] {08c5d643-1a31-42dd-a1ea-171c3fb85b1f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToDistrict (must be UInt32): In scope SELECT regionToDistrict([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1131, line 1133) (in query: SELECT regionToDistrict([]);) 2025.07.13 02:39:20.301932 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToDistrict (must be UInt32): In scope SELECT regionToDistrict([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.333230 [ 32979 ] {5d3a8f7e-15ca-4956-84aa-0cb7d6ae618a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function regionToName (must be UInt32): In scope SELECT regionToName([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1132, line 1134) (in query: SELECT regionToName([]);) 2025.07.13 02:39:20.339128 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function regionToName (must be UInt32): In scope SELECT regionToName([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.388055 [ 32979 ] {1e1ac36a-153c-4bb4-b0e9-53940870f9f3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToPopulation (must be UInt32): In scope SELECT regionToPopulation([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1133, line 1135) (in query: SELECT regionToPopulation([]);) 2025.07.13 02:39:20.398568 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToPopulation (must be UInt32): In scope SELECT regionToPopulation([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.441476 [ 32979 ] {91b79545-219d-40c7-8fc9-3fa577e937dc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToTopContinent (must be UInt32): In scope SELECT regionToTopContinent([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1134, line 1136) (in query: SELECT regionToTopContinent([]);) 2025.07.13 02:39:20.447870 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToTopContinent (must be UInt32): In scope SELECT regionToTopContinent([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.518203 [ 32979 ] {98df7c51-4cd5-4e5f-9ad9-6dae1ab89f7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 1, should be 2: In scope SELECT reinterpret([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1135, line 1137) (in query: SELECT reinterpret([]);) 2025.07.13 02:39:20.523105 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 1, should be 2: In scope SELECT reinterpret([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:20.621406 [ 32979 ] {4ae5c5e4-be54-49ac-ae0e-2fd3cffe8315} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Date because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsDate([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1136, line 1138) (in query: SELECT reinterpretAsDate([]);) 2025.07.13 02:39:20.624552 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Date because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsDate([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.666916 [ 32979 ] {fbbeb6f6-45e6-4f96-a112-ac2add23905b} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as DateTime because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1137, line 1139) (in query: SELECT reinterpretAsDateTime([]);) 2025.07.13 02:39:20.676994 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as DateTime because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.721439 [ 32979 ] {aa299623-dc0b-4f48-9ebe-95574bfb206a} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpretAsFixedString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1138, line 1140) (in query: SELECT reinterpretAsFixedString([]);) 2025.07.13 02:39:20.726893 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpretAsFixedString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.810827 [ 32979 ] {ba220bf0-c963-4288-8943-137de7218b88} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Float32 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsFloat32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1139, line 1141) (in query: SELECT reinterpretAsFloat32([]);) 2025.07.13 02:39:20.816552 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Float32 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsFloat32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.939803 [ 32979 ] {7cf39cde-5f58-45b9-800c-d11af32111d9} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Float64 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsFloat64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1140, line 1142) (in query: SELECT reinterpretAsFloat64([]);) 2025.07.13 02:39:20.945436 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Float64 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsFloat64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:20.992583 [ 32979 ] {8bad9b09-201a-4930-8084-06c89d80ddb6} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int128 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1141, line 1143) (in query: SELECT reinterpretAsInt128([]);) 2025.07.13 02:39:20.997872 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int128 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.029410 [ 32979 ] {2657b731-f20e-4b5f-9443-20495764437b} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int16 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1142, line 1144) (in query: SELECT reinterpretAsInt16([]);) 2025.07.13 02:39:21.034882 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int16 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.117170 [ 32979 ] {db0310f9-bec3-4d63-9f50-b266cf821882} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int256 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1143, line 1145) (in query: SELECT reinterpretAsInt256([]);) 2025.07.13 02:39:21.127227 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int256 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.188749 [ 32979 ] {dad2c093-ad79-4fb4-b950-c9293622db7c} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int32 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1144, line 1146) (in query: SELECT reinterpretAsInt32([]);) 2025.07.13 02:39:21.194401 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int32 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.243959 [ 32979 ] {5741df0c-e358-40d2-8ca9-056f44371b4f} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int64 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1145, line 1147) (in query: SELECT reinterpretAsInt64([]);) 2025.07.13 02:39:21.252452 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int64 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.307699 [ 32979 ] {d7a99456-db69-4aff-8056-cb133e08a322} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int8 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1146, line 1148) (in query: SELECT reinterpretAsInt8([]);) 2025.07.13 02:39:21.312974 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as Int8 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.355113 [ 32979 ] {626047f4-d434-4bcd-b872-cb355c077089} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as String because it is not contiguous in memory: In scope SELECT reinterpretAsString([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1147, line 1149) (in query: SELECT reinterpretAsString([]);) 2025.07.13 02:39:21.372379 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as String because it is not contiguous in memory: In scope SELECT reinterpretAsString([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.420693 [ 32979 ] {2cca9e84-44c3-4e2e-9db5-04592c5c9878} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt128 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1148, line 1150) (in query: SELECT reinterpretAsUInt128([]);) 2025.07.13 02:39:21.433383 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt128 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.456634 [ 32979 ] {354eb6ca-12f6-48d6-9f65-6b43999aa239} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt16 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1149, line 1151) (in query: SELECT reinterpretAsUInt16([]);) 2025.07.13 02:39:21.461294 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt16 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.484053 [ 32979 ] {4a32683c-ff37-4c24-b8f1-1d96edd224ee} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt256 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1150, line 1152) (in query: SELECT reinterpretAsUInt256([]);) 2025.07.13 02:39:21.492631 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt256 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.561351 [ 32979 ] {b8d67152-e9b8-4cf7-91f7-08e7365fd52c} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt32 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1151, line 1153) (in query: SELECT reinterpretAsUInt32([]);) 2025.07.13 02:39:21.571477 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt32 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.605976 [ 32979 ] {55595967-d42e-4df4-9b57-a86d467e0af5} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt64 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1152, line 1154) (in query: SELECT reinterpretAsUInt64([]);) 2025.07.13 02:39:21.610168 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt64 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.639496 [ 32979 ] {34d342c5-ca45-4fe8-8fc5-dd556d0021e2} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt8 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1153, line 1155) (in query: SELECT reinterpretAsUInt8([]);) 2025.07.13 02:39:21.736333 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UInt8 because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.780595 [ 32979 ] {315ae235-6e3d-46ef-84c3-a476f41e9e73} executeQuery: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UUID because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUUID([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1154, line 1156) (in query: SELECT reinterpretAsUUID([]);) 2025.07.13 02:39:21.790639 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret Array(Nothing) as UUID because only Numeric, String or FixedString can be reinterpreted in Numeric: In scope SELECT reinterpretAsUUID([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:21.813319 [ 32979 ] {0d131a49-6afe-4233-991d-0942e1296701} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 1, should be 2: In scope SELECT repeat([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1155, line 1157) (in query: SELECT repeat([]);) 2025.07.13 02:39:21.816580 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 1, should be 2: In scope SELECT repeat([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:21.842227 [ 32979 ] {adac09b0-25ff-43ad-b5d9-79dda829ec27} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replace([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1156, line 1158) (in query: SELECT replace([]);) 2025.07.13 02:39:21.850680 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replace([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:21.993931 [ 32979 ] {c8b29f09-2f2b-47a0-836a-e9359c8b8703} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replaceAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1157, line 1159) (in query: SELECT replaceAll([]);) 2025.07.13 02:39:21.998710 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replaceAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.032032 [ 32979 ] {77cfaae8-9b27-4abb-b9e0-9ab5ae6abc69} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 1, should be 3: In scope SELECT replaceOne([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1158, line 1160) (in query: SELECT replaceOne([]);) 2025.07.13 02:39:22.037786 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 1, should be 3: In scope SELECT replaceOne([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.061030 [ 32979 ] {cfbe1e26-47e3-4440-bc28-54fa0a0e8b44} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1159, line 1161) (in query: SELECT replaceRegexpAll([]);) 2025.07.13 02:39:22.065447 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpAll([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.162926 [ 32979 ] {cdf7b9bd-5db6-4b19-b1aa-5429ddc931c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpOne([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1160, line 1162) (in query: SELECT replaceRegexpOne([]);) 2025.07.13 02:39:22.166462 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpOne([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.185136 [ 32979 ] {d0328d31-ade3-42a2-85c2-eddc70dc3a85} executeQuery: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 1: In scope SELECT replicate([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1161, line 1163) (in query: SELECT replicate([]);) 2025.07.13 02:39:22.188193 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 1: In scope SELECT replicate([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:22.202523 [ 32979 ] {4e093e0b-5a04-447a-b241-4bcf0b843ead} executeQuery: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1162, line 1164) (in query: SELECT retention([]);) 2025.07.13 02:39:22.205356 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.261299 [ 32979 ] {a36ab664-c275-4940-bf48-7f13a6955ff0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function reverseUTF8: In scope SELECT reverseUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1164, line 1166) (in query: SELECT reverseUTF8([]);) 2025.07.13 02:39:22.264028 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function reverseUTF8: In scope SELECT reverseUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:22.283661 [ 32979 ] {7bff8249-090a-4309-883a-39a3c73396ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 1, should be 0: In scope SELECT revision([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1165, line 1167) (in query: SELECT revision([]);) 2025.07.13 02:39:22.286283 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 1, should be 0: In scope SELECT revision([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.305690 [ 32979 ] {1330b099-176d-4e1c-afc0-297a49a944f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 1, should be 2: In scope SELECT right([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1166, line 1168) (in query: SELECT right([]);) 2025.07.13 02:39:22.310422 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 1, should be 2: In scope SELECT right([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.338965 [ 32979 ] {ec3d53b0-d65c-4a96-a611-b2734db52143} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1167, line 1169) (in query: SELECT rightPad([]);) 2025.07.13 02:39:22.345077 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.369127 [ 32979 ] {7d2319c2-1ac0-4247-be76-1f6eb5ff0678} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPadUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1168, line 1170) (in query: SELECT rightPadUTF8([]);) 2025.07.13 02:39:22.374568 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPadUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.400557 [ 32979 ] {8f0a618b-5601-48a2-8a30-bec30fd2a4fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 1, should be 2: In scope SELECT rightUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1169, line 1171) (in query: SELECT rightUTF8([]);) 2025.07.13 02:39:22.405219 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 1, should be 2: In scope SELECT rightUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.439602 [ 32979 ] {4ddb0ae6-4845-45ca-aace-9bed75f95706} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'round'. Expected: A number to round, got: Array(Nothing): In scope SELECT round([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1170, line 1172) (in query: SELECT round([]);) 2025.07.13 02:39:22.445268 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'round'. Expected: A number to round, got: Array(Nothing): In scope SELECT round([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:22.473064 [ 32979 ] {d37ed89c-c4c4-4c9b-88ff-83452dd9d1aa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function roundAge: In scope SELECT roundAge([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1171, line 1173) (in query: SELECT roundAge([]);) 2025.07.13 02:39:22.479438 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function roundAge: In scope SELECT roundAge([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:22.568302 [ 32979 ] {1ac0fc80-896c-4c3c-937b-4d6701295955} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'roundBankers'. Expected: A number to round, got: Array(Nothing): In scope SELECT roundBankers([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1172, line 1174) (in query: SELECT roundBankers([]);) 2025.07.13 02:39:22.581136 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'roundBankers'. Expected: A number to round, got: Array(Nothing): In scope SELECT roundBankers([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:22.622565 [ 32979 ] {ff607215-8401-43c8-8a33-972a5155cb17} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 1, should be 2: In scope SELECT roundDown([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1173, line 1175) (in query: SELECT roundDown([]);) 2025.07.13 02:39:22.631516 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 1, should be 2: In scope SELECT roundDown([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.699082 [ 32979 ] {fedc9718-34cd-4cfa-9687-9165224fbe29} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function roundDuration: In scope SELECT roundDuration([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1174, line 1176) (in query: SELECT roundDuration([]);) 2025.07.13 02:39:22.702335 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function roundDuration: In scope SELECT roundDuration([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:22.724041 [ 32979 ] {947e92e6-3018-42a0-9b04-13770e73a14a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function roundToExp2: In scope SELECT roundToExp2([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1175, line 1177) (in query: SELECT roundToExp2([]);) 2025.07.13 02:39:22.752635 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function roundToExp2: In scope SELECT roundToExp2([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:22.797110 [ 32979 ] {6d631b4e-5072-4027-b1c0-12e5be2beae8} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 1, should be 0: In scope SELECT rowNumberInAllBlocks([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1176, line 1178) (in query: SELECT rowNumberInAllBlocks([]);) 2025.07.13 02:39:22.804140 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 1, should be 0: In scope SELECT rowNumberInAllBlocks([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.859037 [ 32979 ] {7d17191a-f0a8-43bf-9bf5-ec30e010cf2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 1, should be 0: In scope SELECT rowNumberInBlock([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1177, line 1179) (in query: SELECT rowNumberInBlock([]);) 2025.07.13 02:39:22.862419 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 1, should be 0: In scope SELECT rowNumberInBlock([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:22.905974 [ 32979 ] {99e737fd-7a6c-4c71-b015-2918aeec4a00} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1178, line 1180) (in query: SELECT row_number([]);) 2025.07.13 02:39:22.910712 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.07.13 02:39:22.959705 [ 32979 ] {fcbbd43e-12d3-4394-bf8d-d08ed95a9305} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rpad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1179, line 1181) (in query: SELECT rpad([]);) 2025.07.13 02:39:22.968389 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rpad([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.100348 [ 32979 ] {02de0923-3c5b-4b8d-abd6-e8eea35a20a4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Array(Nothing): In scope SELECT trimRight([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1180, line 1182) (in query: SELECT rtrim([]);) 2025.07.13 02:39:23.103192 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Array(Nothing): In scope SELECT trimRight([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:23.122452 [ 32979 ] {1e338c2b-67fa-4908-8d77-d94ab073d4ff} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1181, line 1183) (in query: SELECT runningAccumulate([]);) 2025.07.13 02:39:23.135329 [ 32979 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.07.13 02:39:23.156494 [ 32979 ] {38cc6c6e-f58e-4f2e-9b86-33922f97bbd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 1, should be 2: In scope SELECT runningConcurrency([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1182, line 1184) (in query: SELECT runningConcurrency([]);) 2025.07.13 02:39:23.159399 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 1, should be 2: In scope SELECT runningConcurrency([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.192324 [ 32979 ] {38b2b917-9f71-4de3-a82f-fc6ab6042fce} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1183, line 1185) (in query: SELECT runningDifference([]);) 2025.07.13 02:39:23.195593 [ 32979 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.07.13 02:39:23.219187 [ 32979 ] {2609d6ce-09c1-48cc-b0d7-940a6ab9b609} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1184, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue([]);) 2025.07.13 02:39:23.223127 [ 32979 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.07.13 02:39:23.251632 [ 32979 ] {77a601b7-7d36-41ad-9537-f3a083ea68d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 1, should be 3: In scope SELECT s2CapContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1185, line 1187) (in query: SELECT s2CapContains([]);) 2025.07.13 02:39:23.255477 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 1, should be 3: In scope SELECT s2CapContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.280216 [ 32979 ] {82278829-7ba6-470b-a6d2-2fa9a30b6539} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 1, should be 4: In scope SELECT s2CapUnion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1186, line 1188) (in query: SELECT s2CapUnion([]);) 2025.07.13 02:39:23.283977 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 1, should be 4: In scope SELECT s2CapUnion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.369685 [ 32979 ] {58e49842-305c-4527-8465-be8b657deb89} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 1, should be 2: In scope SELECT s2CellsIntersect([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1187, line 1189) (in query: SELECT s2CellsIntersect([]);) 2025.07.13 02:39:23.374498 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 1, should be 2: In scope SELECT s2CellsIntersect([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.420197 [ 32979 ] {029abf65-3771-4e2d-96a4-c200473ce5c6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function s2GetNeighbors. Must be UInt64: In scope SELECT s2GetNeighbors([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1188, line 1190) (in query: SELECT s2GetNeighbors([]);) 2025.07.13 02:39:23.425909 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function s2GetNeighbors. Must be UInt64: In scope SELECT s2GetNeighbors([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:23.456452 [ 32979 ] {c11b978b-77f5-47f3-9881-aaefdb71cdf7} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 1, should be 3: In scope SELECT s2RectAdd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1189, line 1191) (in query: SELECT s2RectAdd([]);) 2025.07.13 02:39:23.461257 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 1, should be 3: In scope SELECT s2RectAdd([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.493745 [ 32979 ] {a5be82ae-d542-4a22-8cef-ae9cc60992fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 1, should be 3: In scope SELECT s2RectContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1190, line 1192) (in query: SELECT s2RectContains([]);) 2025.07.13 02:39:23.498215 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 1, should be 3: In scope SELECT s2RectContains([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.525458 [ 32979 ] {299d02aa-0b60-440f-8f1b-32ecb6c88147} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 1, should be 4: In scope SELECT s2RectIntersection([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1191, line 1193) (in query: SELECT s2RectIntersection([]);) 2025.07.13 02:39:23.531205 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 1, should be 4: In scope SELECT s2RectIntersection([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.561045 [ 32979 ] {952378d3-b79e-480f-b9ad-9fdb423ef40f} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 1, should be 4: In scope SELECT s2RectUnion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1192, line 1194) (in query: SELECT s2RectUnion([]);) 2025.07.13 02:39:23.566954 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 1, should be 4: In scope SELECT s2RectUnion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.596043 [ 32979 ] {7a55d5ce-b64c-42b0-ac16-0e93fb656d15} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1193, line 1195) (in query: SELECT s2ToGeo([]);) 2025.07.13 02:39:23.601778 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:23.642272 [ 32979 ] {a8a1d1ba-a698-49f9-81c1-83c20b111bfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT scalarProduct([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1194, line 1196) (in query: SELECT scalarProduct([]);) 2025.07.13 02:39:23.647714 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT scalarProduct([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.730328 [ 32979 ] {0313a35f-5b14-479e-9fa5-41a741d0d807} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1195, line 1197) (in query: SELECT sequenceCount([]);) 2025.07.13 02:39:23.735208 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.765247 [ 32979 ] {a02fbd89-7e30-4ebf-8ff8-1953f33dd51d} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1196, line 1198) (in query: SELECT sequenceMatch([]);) 2025.07.13 02:39:23.771047 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.807106 [ 32979 ] {591128b7-074c-4e4a-9b97-35e4e13e186f} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1197, line 1199) (in query: SELECT sequenceMatchEvents([]);) 2025.07.13 02:39:23.813825 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.845197 [ 32979 ] {31aeca62-6d6e-4656-97f3-e945a98a3150} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1198, line 1200) (in query: SELECT sequenceNextNode([]);) 2025.07.13 02:39:23.852018 [ 32979 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.07.13 02:39:23.888523 [ 32979 ] {0f6ea4e9-d270-4326-8c89-8419d4150445} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1199, line 1201) (in query: SELECT seriesDecomposeSTL([]);) 2025.07.13 02:39:23.893013 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:23.921246 [ 32979 ] {86bf66c1-8348-49b5-852c-2b8e6fb9deb4} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1200, line 1202) (in query: SELECT seriesOutliersDetectTukey([]);) 2025.07.13 02:39:23.970784 [ 5480 ] {1e292678-5349-4dba-bbd2-863aa9830b39} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 61859.630867 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59866) (comment: 00632_get_sample_block_cache.sql) (query 19, line 67) (in query: SELECT count() FROM ( SELECT x, count() AS c FROM ( SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) ) GROUP BY x ORDER BY x ASC );), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:39:23.996672 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([]). (ILLEGAL_COLUMN) 2025.07.13 02:39:24.027571 [ 5480 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 61859.630867 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:39:24.058614 [ 32979 ] {f69df9a7-ce8b-40b2-8e2f-fbf6ab5ea83f} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1201, line 1203) (in query: SELECT seriesPeriodDetectFFT([]);) 2025.07.13 02:39:24.064582 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([]). (ILLEGAL_COLUMN) 2025.07.13 02:39:24.115731 [ 32979 ] {46b5d1b9-bcef-47d4-87df-87ca399f7a6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimeZone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1202, line 1204) (in query: SELECT serverTimeZone([]);) 2025.07.13 02:39:24.123259 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimeZone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.189262 [ 32979 ] {cd193269-dbc6-4d70-ae43-e57b9e489ecc} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimezone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1203, line 1205) (in query: SELECT serverTimezone([]);) 2025.07.13 02:39:24.194785 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimezone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.243093 [ 32979 ] {3370de1c-3a6b-44b1-887c-e7ae7228d772} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 1, should be 0: In scope SELECT serverUUID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1204, line 1206) (in query: SELECT serverUUID([]);) 2025.07.13 02:39:24.260293 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 1, should be 0: In scope SELECT serverUUID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.263790 [ 7056 ] {bb2d7777-95ae-4e53-a2fe-61b152ee2ff7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39602) (comment: 00632_get_sample_block_cache.sql) (in query: DROP DATABASE IF EXISTS test_gn5iybza SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:39:24.267979 [ 7056 ] {bb2d7777-95ae-4e53-a2fe-61b152ee2ff7} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd54af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5f8cb6 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb7884 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:39:24.347785 [ 32979 ] {6c3eda34-9b79-4a93-8a07-1d6b775e6dff} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 1, should be 0: In scope SELECT shardCount([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1205, line 1207) (in query: SELECT shardCount([]);) 2025.07.13 02:39:24.356619 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 1, should be 0: In scope SELECT shardCount([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.411512 [ 32979 ] {72d847a4-9cf4-46ce-9db5-cec6f00f8ed3} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 1, should be 0: In scope SELECT shardNum([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1206, line 1208) (in query: SELECT shardNum([]);) 2025.07.13 02:39:24.437012 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 1, should be 0: In scope SELECT shardNum([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.557575 [ 32979 ] {14289d46-88bc-4a09-bdc2-13b16226424c} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 1, should be 0: In scope SELECT showCertificate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1207, line 1209) (in query: SELECT showCertificate([]);) 2025.07.13 02:39:24.573611 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 1, should be 0: In scope SELECT showCertificate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.609795 [ 32979 ] {81a8f578-4dda-489f-874e-7d32b66b25b2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sigmoid: In scope SELECT sigmoid([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1208, line 1210) (in query: SELECT sigmoid([]);) 2025.07.13 02:39:24.612396 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sigmoid: In scope SELECT sigmoid([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:24.634673 [ 32979 ] {b88773d0-ba2f-43f9-9424-4e95e9cef7e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sign: In scope SELECT sign([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1209, line 1211) (in query: SELECT sign([]);) 2025.07.13 02:39:24.638679 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sign: In scope SELECT sign([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:24.683517 [ 32979 ] {bb253e77-5126-4324-a13d-3e48871387d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractBool([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1210, line 1212) (in query: SELECT simpleJSONExtractBool([]);) 2025.07.13 02:39:24.710479 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractBool([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.877612 [ 32979 ] {cbd5fead-79d1-4c74-bfbb-143c60ed8c66} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractFloat([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1211, line 1213) (in query: SELECT simpleJSONExtractFloat([]);) 2025.07.13 02:39:24.882887 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractFloat([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.913986 [ 32979 ] {57ec080f-5ec1-484c-8c25-5c108ec21943} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1212, line 1214) (in query: SELECT simpleJSONExtractInt([]);) 2025.07.13 02:39:24.919569 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:24.972696 [ 32979 ] {f7cd446e-cbc8-49ee-acb0-2b1675bfc9f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractRaw([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1213, line 1215) (in query: SELECT simpleJSONExtractRaw([]);) 2025.07.13 02:39:24.978841 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractRaw([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:25.092258 [ 32979 ] {c1617128-30dd-43cb-a437-7005ffed0153} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1214, line 1216) (in query: SELECT simpleJSONExtractString([]);) 2025.07.13 02:39:25.097581 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:25.186582 [ 32979 ] {dc3c75b1-ced3-4d2a-bd38-4cd41de7b75f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractUInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1215, line 1217) (in query: SELECT simpleJSONExtractUInt([]);) 2025.07.13 02:39:25.197975 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractUInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:25.226151 [ 32979 ] {4e6d5611-e39b-4c1a-ada8-791f364f9268} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT simpleJSONHas([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1216, line 1218) (in query: SELECT simpleJSONHas([]);) 2025.07.13 02:39:25.231565 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT simpleJSONHas([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:25.266259 [ 32979 ] {dd91d7d2-d2bd-47f0-bf17-1ba4dcba3074} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1217, line 1219) (in query: SELECT simpleLinearRegression([]);) 2025.07.13 02:39:25.271565 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:25.311622 [ 32979 ] {85755900-6bb8-4792-beb3-b35eabcdcf21} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sin: In scope SELECT sin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1218, line 1220) (in query: SELECT sin([]);) 2025.07.13 02:39:25.316766 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sin: In scope SELECT sin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:25.348150 [ 32979 ] {af5c646d-8b1c-469e-86c8-1be01dc48c88} executeQuery: Code: 43. DB::Exception: Nested type Array(Nothing) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1219, line 1221) (in query: SELECT singleValueOrNull([]);) 2025.07.13 02:39:25.353879 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Array(Nothing) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:25.382282 [ 32979 ] {a0cb7ace-4c27-4ad1-b686-ed2179607351} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sinh: In scope SELECT sinh([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1220, line 1222) (in query: SELECT sinh([]);) 2025.07.13 02:39:25.387452 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sinh: In scope SELECT sinh([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:25.477331 [ 32979 ] {df4b717c-9e7b-403b-8cc3-7e521b0cd975} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1222, line 1224) (in query: SELECT sipHash128Keyed([]);) 2025.07.13 02:39:25.482908 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([]). (BAD_ARGUMENTS) 2025.07.13 02:39:25.591687 [ 32979 ] {dbdf005f-f268-4ae9-b112-a931f1050231} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1224, line 1226) (in query: SELECT sipHash128ReferenceKeyed([]);) 2025.07.13 02:39:25.596736 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([]). (BAD_ARGUMENTS) 2025.07.13 02:39:25.742536 [ 32979 ] {9a401015-d7e7-4e64-b37b-a94092039a7b} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1226, line 1228) (in query: SELECT sipHash64Keyed([]);) 2025.07.13 02:39:25.755570 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([]). (BAD_ARGUMENTS) 2025.07.13 02:39:25.870348 [ 32979 ] {ddfa7571-0144-41db-8737-d5ebfe46456a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function skewPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1227, line 1229) (in query: SELECT skewPop([]);) 2025.07.13 02:39:25.887219 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function skewPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:25.944393 [ 32979 ] {c07bab00-f83a-429b-a209-3603bc9a1897} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function skewSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1228, line 1230) (in query: SELECT skewSamp([]);) 2025.07.13 02:39:25.947370 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function skewSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:25.972572 [ 32979 ] {6ce3fd52-20fd-429b-9a4c-322ae1fff157} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sleep, expected UInt* or Float*: In scope SELECT sleep([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1229, line 1231) (in query: SELECT sleep([]);) 2025.07.13 02:39:25.975642 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sleep, expected UInt* or Float*: In scope SELECT sleep([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.018527 [ 32979 ] {86743c1f-93ad-4555-881c-1d1163f56604} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sleepEachRow, expected UInt* or Float*: In scope SELECT sleepEachRow([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1230, line 1232) (in query: SELECT sleepEachRow([]);) 2025.07.13 02:39:26.030655 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sleepEachRow, expected UInt* or Float*: In scope SELECT sleepEachRow([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.060200 [ 32979 ] {1b6b740b-c293-42e9-9ceb-bbf20fc677ea} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1231, line 1233) (in query: SELECT snowflakeIDToDateTime([]);) 2025.07.13 02:39:26.063105 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.086085 [ 32979 ] {f958ae85-8f49-4d23-926d-d05bdbc20c47} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1232, line 1234) (in query: SELECT snowflakeIDToDateTime64([]);) 2025.07.13 02:39:26.094002 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.127461 [ 32979 ] {a6a580af-dd0e-43fb-85e1-bcf8e0b7523a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1233, line 1235) (in query: SELECT snowflakeToDateTime([]);) 2025.07.13 02:39:26.132614 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.160543 [ 32979 ] {04862c8d-ba69-498b-b10c-652e9c67a3dc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1234, line 1236) (in query: SELECT snowflakeToDateTime64([]);) 2025.07.13 02:39:26.165267 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.284656 [ 32979 ] {4f08344b-3622-4ed9-b15d-bdfc21b198d8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function soundex: In scope SELECT soundex([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1235, line 1237) (in query: SELECT soundex([]);) 2025.07.13 02:39:26.290388 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function soundex: In scope SELECT soundex([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.393330 [ 32979 ] {62ac3c50-193f-4436-9d74-30bcde7719db} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: Array(Nothing): In scope SELECT space([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1236, line 1238) (in query: SELECT space([]);) 2025.07.13 02:39:26.395946 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: Array(Nothing): In scope SELECT space([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.415884 [ 32979 ] {08a9c669-2329-4825-9c75-88eb5a275166} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1237, line 1239) (in query: SELECT sparkBar([]);) 2025.07.13 02:39:26.418616 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:26.446207 [ 32979 ] {8a8de723-456b-498f-a9fb-f7d123b8e625} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1238, line 1240) (in query: SELECT sparkbar([]);) 2025.07.13 02:39:26.456410 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:26.486216 [ 32979 ] {7edacc71-5984-4edb-a34d-28530dcc2a74} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT splitByAlpha([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1239, line 1241) (in query: SELECT splitByAlpha([]);) 2025.07.13 02:39:26.491982 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT splitByAlpha([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.519996 [ 32979 ] {d1fb2512-ef1a-4d5e-8e6c-1c14347898ff} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByChar([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1240, line 1242) (in query: SELECT splitByChar([]);) 2025.07.13 02:39:26.525246 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByChar([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:26.555207 [ 32979 ] {24ad59c4-a719-4efa-b332-4c86d5fde60e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByNonAlpha'. Expected: String, got: Array(Nothing): In scope SELECT splitByNonAlpha([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1241, line 1243) (in query: SELECT splitByNonAlpha([]);) 2025.07.13 02:39:26.561995 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByNonAlpha'. Expected: String, got: Array(Nothing): In scope SELECT splitByNonAlpha([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.600275 [ 32979 ] {a1371640-529d-4b06-855f-596c243252aa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByRegexp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1242, line 1244) (in query: SELECT splitByRegexp([]);) 2025.07.13 02:39:26.605502 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByRegexp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:26.643597 [ 32979 ] {8f72c781-f2fa-4ba7-9552-59b942157ea5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1243, line 1245) (in query: SELECT splitByString([]);) 2025.07.13 02:39:26.657530 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:26.729548 [ 32979 ] {a83e88a7-ec49-4dce-98e5-c75fd84ee187} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByWhitespace'. Expected: String, got: Array(Nothing): In scope SELECT splitByWhitespace([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1244, line 1246) (in query: SELECT splitByWhitespace([]);) 2025.07.13 02:39:26.734681 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByWhitespace'. Expected: String, got: Array(Nothing): In scope SELECT splitByWhitespace([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.767327 [ 32979 ] {2eceed3e-0f1a-453a-a0c4-e2b36dfd3bdf} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqid([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1245, line 1247) (in query: SELECT sqid([]);) 2025.07.13 02:39:26.835307 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqid([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.871059 [ 32979 ] {96cc05ab-a8db-4ff2-aa1f-37f0fd0815b2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'sqid' to function 'sqidDecode'. Expected: String, got: Array(Nothing): In scope SELECT sqidDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1246, line 1248) (in query: SELECT sqidDecode([]);) 2025.07.13 02:39:26.875432 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'sqid' to function 'sqidDecode'. Expected: String, got: Array(Nothing): In scope SELECT sqidDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.909435 [ 32979 ] {fa33d2e8-64f9-4e57-b389-65513747aa32} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqidEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1247, line 1249) (in query: SELECT sqidEncode([]);) 2025.07.13 02:39:26.913757 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqidEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.945386 [ 32979 ] {31e8c261-9e1d-43eb-a9a5-b11a564f759c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sqrt: In scope SELECT sqrt([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1248, line 1250) (in query: SELECT sqrt([]);) 2025.07.13 02:39:26.950037 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function sqrt: In scope SELECT sqrt([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:26.984287 [ 32979 ] {5948744d-7c43-47a9-879c-42deef9d03aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 1, should be 2: In scope SELECT startsWith([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1249, line 1251) (in query: SELECT startsWith([]);) 2025.07.13 02:39:26.988517 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 1, should be 2: In scope SELECT startsWith([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:27.024383 [ 32979 ] {7ccbaf37-a4ab-4079-be00-bf55b1663926} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT startsWithUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1250, line 1252) (in query: SELECT startsWithUTF8([]);) 2025.07.13 02:39:27.028954 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT startsWithUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:27.141179 [ 32979 ] {f40e8b00-3031-4db8-9231-7213a8bb4cb5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1251, line 1253) (in query: SELECT stddevPop([]);) 2025.07.13 02:39:27.158245 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:27.275396 [ 32979 ] {7f0a8eae-aa31-44c0-ac89-e17838aaa67b} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1252, line 1254) (in query: SELECT stddevPopStable([]);) 2025.07.13 02:39:27.301527 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.07.13 02:39:27.328218 [ 32979 ] {be1f883e-651e-4ad4-a879-666363125256} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1253, line 1255) (in query: SELECT stddevSamp([]);) 2025.07.13 02:39:27.333902 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function stddevSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:27.413996 [ 32979 ] {f07ed37e-d3d2-4038-8276-7e04dd025cbe} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1254, line 1256) (in query: SELECT stddevSampStable([]);) 2025.07.13 02:39:27.418636 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.07.13 02:39:27.465575 [ 32979 ] {29fb8b1d-eac6-4baf-86e9-7be8e6e95cb8} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1255, line 1257) (in query: SELECT stem([]);) 2025.07.13 02:39:27.506468 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:39:27.612355 [ 32979 ] {46e4a7d8-1fa1-4c36-a4ce-c7c35fdb144f} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1256, line 1258) (in query: SELECT stochasticLinearRegression([]);) 2025.07.13 02:39:27.619905 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:27.647359 [ 32979 ] {d9be1ceb-9378-4a8b-97bf-f5d6bc7727ec} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1257, line 1259) (in query: SELECT stochasticLogisticRegression([]);) 2025.07.13 02:39:27.652226 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:27.682373 [ 32979 ] {f30a7ae5-171c-47a4-a1f2-48004f422f14} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT str_to_date([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1258, line 1260) (in query: SELECT str_to_date([]);) 2025.07.13 02:39:27.687691 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT str_to_date([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:27.715153 [ 32979 ] {561dd5d3-14a6-4815-8307-f1ab83e4f03e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT str_to_map([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1259, line 1261) (in query: SELECT str_to_map([]);) 2025.07.13 02:39:27.720268 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT str_to_map([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:27.751608 [ 32979 ] {882ee718-d9aa-48b4-8c21-96996951d623} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1260, line 1262) (in query: SELECT stringJaccardIndex([]);) 2025.07.13 02:39:27.756375 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:27.846662 [ 32979 ] {17ebe869-47be-4561-ac0b-f7fb2c39ef58} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndexUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1261, line 1263) (in query: SELECT stringJaccardIndexUTF8([]);) 2025.07.13 02:39:27.851659 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndexUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:27.880104 [ 32979 ] {63049d62-c8db-40b5-a247-f322e769f9b7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function stringToH3. Must be String or FixedString: In scope SELECT stringToH3([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1262, line 1264) (in query: SELECT stringToH3([]);) 2025.07.13 02:39:27.884968 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function stringToH3. Must be String or FixedString: In scope SELECT stringToH3([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:27.921984 [ 32979 ] {a0a2b949-b853-4f49-881b-8f190a43e770} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1263, line 1265) (in query: SELECT structureToCapnProtoSchema([]);) 2025.07.13 02:39:27.953407 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:28.129566 [ 32979 ] {ce5cd08a-77f2-4d58-9d03-51fa7cc4f407} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1264, line 1266) (in query: SELECT structureToProtobufSchema([]);) 2025.07.13 02:39:28.134829 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:28.167331 [ 32979 ] {80f977a7-6f5b-4181-bf69-b1b16a45b7ba} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1265, line 1267) (in query: SELECT studentTTest([]);) 2025.07.13 02:39:28.182230 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.224602 [ 32979 ] {994f3132-5db1-4e9a-b99c-e029d863cff6} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 1, should be 3: In scope SELECT subBitmap([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1266, line 1268) (in query: SELECT subBitmap([]);) 2025.07.13 02:39:28.229922 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 1, should be 3: In scope SELECT subBitmap([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.259392 [ 32979 ] {7757cd2e-6efe-4df5-bca2-f566b1c77a1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1267, line 1269) (in query: SELECT subDate([]);) 2025.07.13 02:39:28.271968 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.302511 [ 32979 ] {fd55f609-8832-4cf9-908c-8f2f8fc4defa} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT substr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1268, line 1270) (in query: SELECT substr([]);) 2025.07.13 02:39:28.308032 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT substr([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.340827 [ 32979 ] {a1b4a16e-342a-4eee-90d0-1165f95f6da9} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT substringIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1269, line 1272) (in query: SELECT substringIndex([]);) 2025.07.13 02:39:28.346899 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT substringIndex([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.378332 [ 32979 ] {f9e600ca-399a-4947-baec-0d249394805b} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 1, should be 3: In scope SELECT substringIndexUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1270, line 1273) (in query: SELECT substringIndexUTF8([]);) 2025.07.13 02:39:28.383835 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 1, should be 3: In scope SELECT substringIndexUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.414712 [ 32979 ] {a8436e91-1035-49dc-80b9-e0d8ddfd512b} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT substringUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1271, line 1274) (in query: SELECT substringUTF8([]);) 2025.07.13 02:39:28.420640 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT substringUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.449338 [ 32979 ] {a02b9435-9c75-409c-aee1-7030e99a6946} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractDays([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1272, line 1275) (in query: SELECT subtractDays([]);) 2025.07.13 02:39:28.454575 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractDays([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.494062 [ 32979 ] {db7a1261-48fd-40d6-a621-efc780829d41} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractHours([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1273, line 1276) (in query: SELECT subtractHours([]);) 2025.07.13 02:39:28.499275 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractHours([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.557421 [ 32979 ] {e4d20ac8-9a69-4f3c-88a1-13a556009efe} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 1, should be 2: In scope SELECT subtractInterval([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1274, line 1277) (in query: SELECT subtractInterval([]);) 2025.07.13 02:39:28.563361 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 1, should be 2: In scope SELECT subtractInterval([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.616002 [ 32979 ] {9c0b30af-7710-4cd7-badb-8a09741bdb91} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMicroseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1275, line 1278) (in query: SELECT subtractMicroseconds([]);) 2025.07.13 02:39:28.634567 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMicroseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.796452 [ 32979 ] {594abd01-df22-4d73-8969-c082b196b01a} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMilliseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1276, line 1279) (in query: SELECT subtractMilliseconds([]);) 2025.07.13 02:39:28.799764 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMilliseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.831188 [ 32979 ] {77fe41f4-6f85-4534-a549-4bf54372faa7} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMinutes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1277, line 1280) (in query: SELECT subtractMinutes([]);) 2025.07.13 02:39:28.835201 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMinutes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.921209 [ 32979 ] {6d632809-899e-49b3-8f50-fca71983ef6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMonths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1278, line 1281) (in query: SELECT subtractMonths([]);) 2025.07.13 02:39:28.924504 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMonths([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:28.995718 [ 32979 ] {221f3d9e-ee7f-4a36-a1c0-5c6db59829b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractNanoseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1279, line 1282) (in query: SELECT subtractNanoseconds([]);) 2025.07.13 02:39:28.999123 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractNanoseconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.071205 [ 32979 ] {e1811842-c023-419d-8532-f0485ce3f171} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractQuarters([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1280, line 1283) (in query: SELECT subtractQuarters([]);) 2025.07.13 02:39:29.074902 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractQuarters([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.093013 [ 32979 ] {44d3ff59-d128-410d-b255-2e109d78a0eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractSeconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1281, line 1284) (in query: SELECT subtractSeconds([]);) 2025.07.13 02:39:29.096634 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractSeconds([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.115262 [ 32979 ] {aef40bdd-a5a1-46ba-954f-1202033b6e11} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT subtractTupleOfIntervals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1282, line 1285) (in query: SELECT subtractTupleOfIntervals([]);) 2025.07.13 02:39:29.118213 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT subtractTupleOfIntervals([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.149557 [ 32979 ] {6d6f04b6-9319-4acb-9205-3f201f365cd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractWeeks([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1283, line 1286) (in query: SELECT subtractWeeks([]);) 2025.07.13 02:39:29.152700 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractWeeks([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.171665 [ 32979 ] {1361f3b5-4874-4502-a2a9-b8e04da00ade} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractYears([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1284, line 1287) (in query: SELECT subtractYears([]);) 2025.07.13 02:39:29.174950 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractYears([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.196491 [ 32979 ] {cedddeec-7652-40b1-ad48-04fafd60b774} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sum. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1285, line 1288) (in query: SELECT sum([]);) 2025.07.13 02:39:29.199743 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sum. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.216682 [ 32979 ] {7f5e0e66-fe1c-4775-9e46-163b740b0041} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sumCount. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1286, line 1289) (in query: SELECT sumCount([]);) 2025.07.13 02:39:29.219663 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sumCount. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.275905 [ 32979 ] {73b4b045-bcb3-4d7b-914f-06b0fcc07915} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sumKahan. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1287, line 1290) (in query: SELECT sumKahan([]);) 2025.07.13 02:39:29.279550 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sumKahan. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.325640 [ 32979 ] {7e56c547-df19-4fb8-aae3-28bb0bebf70b} executeQuery: Code: 43. DB::Exception: When function sumMapFiltered gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1288, line 1291) (in query: SELECT sumMapFiltered([]);) 2025.07.13 02:39:29.329621 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMapFiltered gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.352479 [ 32979 ] {f3355f41-58d8-492c-8c3b-01c78d40c7d6} executeQuery: Code: 43. DB::Exception: When function sumMapFilteredWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1289, line 1292) (in query: SELECT sumMapFilteredWithOverflow([]);) 2025.07.13 02:39:29.355940 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMapFilteredWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.384529 [ 32979 ] {1007174b-c268-439f-aedb-22b9508fecca} executeQuery: Code: 43. DB::Exception: When function sumMapWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1290, line 1293) (in query: SELECT sumMapWithOverflow([]);) 2025.07.13 02:39:29.390284 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMapWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.429128 [ 32979 ] {399b26f7-9dc8-49f0-9d75-8234ae0fe241} executeQuery: Code: 43. DB::Exception: When function sumMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1291, line 1294) (in query: SELECT sumMappedArrays([]);) 2025.07.13 02:39:29.433245 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.507308 [ 32979 ] {b9f64bc4-c6a9-46ac-b771-94f2b1bfbdb0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sumWithOverflow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1292, line 1295) (in query: SELECT sumWithOverflow([]);) 2025.07.13 02:39:29.514246 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function sumWithOverflow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.565601 [ 32979 ] {d8a0dd0c-90d3-4087-bd28-3fa1a21aace4} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT svg([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1293, line 1296) (in query: SELECT svg([]);) 2025.07.13 02:39:29.569884 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT svg([]). (BAD_ARGUMENTS) 2025.07.13 02:39:29.593389 [ 32979 ] {c59176b8-e1ee-45d5-9f2d-645527202d8b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1294, line 1297) (in query: SELECT synonyms([]);) 2025.07.13 02:39:29.597767 [ 32979 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.07.13 02:39:29.638089 [ 32979 ] {682f9ee9-60e2-4ce4-b73a-64f514c0f03b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tan: In scope SELECT tan([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1295, line 1298) (in query: SELECT tan([]);) 2025.07.13 02:39:29.644589 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tan: In scope SELECT tan([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.679689 [ 32979 ] {c4a057ab-d21c-4994-bef2-ac03bd8afd19} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tanh: In scope SELECT tanh([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1296, line 1299) (in query: SELECT tanh([]);) 2025.07.13 02:39:29.685331 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tanh: In scope SELECT tanh([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.720599 [ 32979 ] {0a985194-4d76-4f55-be2e-9f9626fef066} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 1, should be 0: In scope SELECT tcpPort([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1297, line 1300) (in query: SELECT tcpPort([]);) 2025.07.13 02:39:29.726195 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 1, should be 0: In scope SELECT tcpPort([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.784596 [ 32979 ] {bf635b55-1559-4c7d-b5ff-5084e21578f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 1, should be 2: In scope SELECT test_function([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1298, line 1301) (in query: SELECT test_function([]);) 2025.07.13 02:39:29.790534 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 1, should be 2: In scope SELECT test_function([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.831552 [ 32979 ] {7d38b703-4edb-4b15-b3bc-100267ca2a5c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tgamma: In scope SELECT tgamma([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1299, line 1302) (in query: SELECT tgamma([]);) 2025.07.13 02:39:29.844806 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tgamma: In scope SELECT tgamma([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.878001 [ 32979 ] {7e6d16b8-062c-4fb0-9ddb-afd8897c695f} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1300, line 1303) (in query: SELECT theilsU([]);) 2025.07.13 02:39:29.883403 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:29.916964 [ 32979 ] {92ed20c1-1056-4888-a239-acac6a151c52} executeQuery: Code: 43. DB::Exception: First argument of function throwIf must be a number (passed: Array(Nothing)): In scope SELECT throwIf([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1301, line 1304) (in query: SELECT throwIf([]);) 2025.07.13 02:39:29.926631 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function throwIf must be a number (passed: Array(Nothing)): In scope SELECT throwIf([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:29.972785 [ 32979 ] {e39f8513-cd72-4bba-9e1a-006ccb38d09e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 1, should be 0: In scope SELECT tid([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1302, line 1305) (in query: SELECT tid([]);) 2025.07.13 02:39:29.978858 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 1, should be 0: In scope SELECT tid([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.080168 [ 32979 ] {5ca8e7ea-a906-4e32-afbe-08744ceb76d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 1, should be 2: In scope SELECT timeDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1303, line 1306) (in query: SELECT timeDiff([]);) 2025.07.13 02:39:30.085737 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 1, should be 2: In scope SELECT timeDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.143092 [ 32979 ] {067fed5b-167c-4f5e-9aaa-6c1312e0a351} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timeSlot. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeSlot([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1304, line 1307) (in query: SELECT timeSlot([]);) 2025.07.13 02:39:30.148631 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timeSlot. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeSlot([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.195760 [ 32979 ] {c579cd5f-398a-41d5-b25d-9735a5b15898} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1305, line 1308) (in query: SELECT timeSlots([]);) 2025.07.13 02:39:30.199734 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.246023 [ 32979 ] {6c37c40a-a557-453f-9030-ab946c9da215} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timeZone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1306, line 1309) (in query: SELECT timeZone([]);) 2025.07.13 02:39:30.251116 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timeZone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.357064 [ 32979 ] {4547481e-a68d-4b40-b1ed-4c69ab2ae696} executeQuery: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timeZoneOf([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1307, line 1310) (in query: SELECT timeZoneOf([]);) 2025.07.13 02:39:30.361774 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timeZoneOf([]). (BAD_ARGUMENTS) 2025.07.13 02:39:30.403240 [ 32979 ] {83751949-b9b0-4ede-bfae-c9d330d9090a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeZoneOffset([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1308, line 1311) (in query: SELECT timeZoneOffset([]);) 2025.07.13 02:39:30.419999 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeZoneOffset([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.475946 [ 32979 ] {c911b99e-a781-487d-9f2f-92db8f223f10} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT time_bucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1309, line 1312) (in query: SELECT time_bucket([]);) 2025.07.13 02:39:30.479943 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT time_bucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.504181 [ 32979 ] {4e01e679-4933-447d-8c42-afdb86ec0cc4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT timestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1310, line 1313) (in query: SELECT timestamp([]);) 2025.07.13 02:39:30.508215 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT timestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.557140 [ 32979 ] {1029549d-2ed3-4aa4-ba24-b4b764cd7f8e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1311, line 1314) (in query: SELECT timestampDiff([]);) 2025.07.13 02:39:30.562158 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.599839 [ 32979 ] {80e63b21-e957-4ac7-bfca-6270c59c1ade} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1312, line 1315) (in query: SELECT timestamp_diff([]);) 2025.07.13 02:39:30.608951 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.637724 [ 32979 ] {b75c8c96-7e4c-4d9b-bf12-80196a045310} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timezone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1313, line 1316) (in query: SELECT timezone([]);) 2025.07.13 02:39:30.642054 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timezone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:30.663398 [ 32979 ] {e5088275-fc55-45f6-9950-c57474d052d7} executeQuery: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timezoneOf([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1314, line 1317) (in query: SELECT timezoneOf([]);) 2025.07.13 02:39:30.668072 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timezoneOf([]). (BAD_ARGUMENTS) 2025.07.13 02:39:30.687669 [ 32979 ] {cf58154c-a23b-4543-bd47-f61e73fead8d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timezoneOffset([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1315, line 1318) (in query: SELECT timezoneOffset([]);) 2025.07.13 02:39:30.692827 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timezoneOffset([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.740775 [ 32979 ] {91b58b7b-6d5e-4693-9e54-800a73b20858} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toBFloat16: In scope SELECT toBFloat16([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1316, line 1319) (in query: SELECT toBFloat16([]);) 2025.07.13 02:39:30.746905 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toBFloat16: In scope SELECT toBFloat16([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.774572 [ 32979 ] {51031a05-a094-4663-ba1e-db3a3c88bd3e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toBFloat16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1317, line 1320) (in query: SELECT toBFloat16OrNull([]);) 2025.07.13 02:39:30.780707 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toBFloat16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.842955 [ 32979 ] {932ac58a-bd7d-42fe-9fe4-92e1a2bff3e2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toBFloat16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1318, line 1321) (in query: SELECT toBFloat16OrZero([]);) 2025.07.13 02:39:30.848590 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toBFloat16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.873024 [ 32979 ] {36888003-1574-45c1-ba89-4df2fab29e8f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt8: In scope SELECT toBool([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1319, line 1322) (in query: SELECT toBool([]);) 2025.07.13 02:39:30.877491 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt8: In scope SELECT toBool([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:30.975897 [ 32979 ] {a2a3c6a4-c7a3-4e99-ab74-9ee3271cf16f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate: In scope SELECT toDate([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1321, line 1324) (in query: SELECT toDate([]);) 2025.07.13 02:39:30.980849 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate: In scope SELECT toDate([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.027438 [ 32979 ] {693834b4-7d02-44e6-86d6-8e6f0fcad875} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate32: In scope SELECT toDate32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1322, line 1325) (in query: SELECT toDate32([]);) 2025.07.13 02:39:31.032390 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate32: In scope SELECT toDate32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.063869 [ 32979 ] {2aff0ceb-d3e1-4b53-bae4-22a4cb3acf82} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate32: In scope SELECT toDate32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1323, line 1326) (in query: SELECT toDate32OrDefault([]);) 2025.07.13 02:39:31.069203 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate32: In scope SELECT toDate32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.139057 [ 32979 ] {d301f073-276a-4bbf-9dc3-114b7a5f512f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1324, line 1327) (in query: SELECT toDate32OrNull([]);) 2025.07.13 02:39:31.145504 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.259828 [ 32979 ] {957cbc37-f46a-47af-8187-82859725e15c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1325, line 1328) (in query: SELECT toDate32OrZero([]);) 2025.07.13 02:39:31.271342 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.307320 [ 32979 ] {fd3eeefd-55bd-4c2a-bab4-bcfd4f6d97de} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate: In scope SELECT toDateOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1326, line 1329) (in query: SELECT toDateOrDefault([]);) 2025.07.13 02:39:31.313100 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDate: In scope SELECT toDateOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.360714 [ 32979 ] {ff37b9f3-f0ac-4504-b1a1-4685257aa072} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1327, line 1330) (in query: SELECT toDateOrNull([]);) 2025.07.13 02:39:31.368854 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.394774 [ 32979 ] {3ef640b8-c512-4cec-9c28-47933eb5670b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1328, line 1331) (in query: SELECT toDateOrZero([]);) 2025.07.13 02:39:31.399406 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.459031 [ 32979 ] {ea15cbec-844e-4683-b785-2603904e65cc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDateTime: In scope SELECT toDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1329, line 1332) (in query: SELECT toDateTime([]);) 2025.07.13 02:39:31.469683 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDateTime: In scope SELECT toDateTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.534730 [ 32979 ] {189438c7-c657-4ad3-bdb0-043ee6119709} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDateTime32: In scope SELECT toDateTime32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1330, line 1333) (in query: SELECT toDateTime32([]);) 2025.07.13 02:39:31.539079 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDateTime32: In scope SELECT toDateTime32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.633249 [ 32979 ] {af45d9cf-0b9c-43b4-a706-9e8caed779a4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDateTime64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1331, line 1334) (in query: SELECT toDateTime64([]);) 2025.07.13 02:39:31.639074 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDateTime64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:31.674722 [ 32979 ] {eaf30585-b858-4a3a-bfd2-6e864b47a7ee} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT toDateTime64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1332, line 1335) (in query: SELECT toDateTime64OrDefault([]);) 2025.07.13 02:39:31.677583 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT toDateTime64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:31.743844 [ 32979 ] {d5e30695-59c1-431d-98ee-596c7cbc5019} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1333, line 1336) (in query: SELECT toDateTime64OrNull([]);) 2025.07.13 02:39:31.752403 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:31.890816 [ 32979 ] {4ba627e3-529b-4d2b-b983-7aae7d72b300} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1334, line 1337) (in query: SELECT toDateTime64OrZero([]);) 2025.07.13 02:39:31.896963 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.031714 [ 32979 ] {53194206-cffb-4cea-b058-64ae12166e68} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDateTime: In scope SELECT toDateTimeOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1335, line 1338) (in query: SELECT toDateTimeOrDefault([]);) 2025.07.13 02:39:32.037083 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDateTime: In scope SELECT toDateTimeOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.084896 [ 32979 ] {e4eba79f-f298-4936-b387-10b73a00e66d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1336, line 1339) (in query: SELECT toDateTimeOrNull([]);) 2025.07.13 02:39:32.089714 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.142791 [ 32979 ] {2f222e03-b35e-4bb2-b8a6-022522b596de} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1337, line 1340) (in query: SELECT toDateTimeOrZero([]);) 2025.07.13 02:39:32.147738 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.275228 [ 32979 ] {5b8fb175-b49f-4d32-862a-c6016d173a27} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1338, line 1341) (in query: SELECT toDayOfMonth([]);) 2025.07.13 02:39:32.280740 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.369793 [ 32979 ] {597493ff-eb85-49ae-bd30-9a3f14132745} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toDayOfWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1339, line 1342) (in query: SELECT toDayOfWeek([]);) 2025.07.13 02:39:32.375072 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toDayOfWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.430341 [ 32979 ] {9fe0b79e-9f20-4255-9482-6960a97f607a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1340, line 1343) (in query: SELECT toDayOfYear([]);) 2025.07.13 02:39:32.435809 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.466185 [ 32979 ] {c80d9734-ffd4-45d3-8673-334242e27501} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1341, line 1344) (in query: SELECT toDaysSinceYearZero([]);) 2025.07.13 02:39:32.471587 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:32.514623 [ 32979 ] {d2f856b2-5f22-4117-ab86-77929900eb08} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal128([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1342, line 1345) (in query: SELECT toDecimal128([]);) 2025.07.13 02:39:32.521089 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal128([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:32.576641 [ 32979 ] {3c2931b1-6c81-4c2f-a618-7f55897cd164} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal128OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1343, line 1346) (in query: SELECT toDecimal128OrDefault([]);) 2025.07.13 02:39:32.582110 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal128OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:32.690896 [ 32979 ] {efb43e72-c69c-4563-974e-dad5f43b2e55} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1344, line 1347) (in query: SELECT toDecimal128OrNull([]);) 2025.07.13 02:39:32.700350 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:32.737377 [ 32979 ] {a2fc6731-cfaf-48c1-baec-afd9c5491e8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1345, line 1348) (in query: SELECT toDecimal128OrZero([]);) 2025.07.13 02:39:32.756063 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:32.797031 [ 32979 ] {05012a52-5775-431a-bf97-5a28fb505a5a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal256([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1346, line 1349) (in query: SELECT toDecimal256([]);) 2025.07.13 02:39:32.803364 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal256([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:32.828079 [ 32979 ] {4cf9a64c-1ee1-4df9-9c0b-ddb6c24bc5d4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal256OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1347, line 1350) (in query: SELECT toDecimal256OrDefault([]);) 2025.07.13 02:39:32.831343 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal256OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:32.929452 [ 32979 ] {cd5e21a4-02d1-438c-b4da-f2baa6bd5389} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1348, line 1351) (in query: SELECT toDecimal256OrNull([]);) 2025.07.13 02:39:32.933125 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.027024 [ 32979 ] {0f576b80-085c-407b-b2ce-b1f57c2e5a38} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1349, line 1352) (in query: SELECT toDecimal256OrZero([]);) 2025.07.13 02:39:33.034709 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.112158 [ 32979 ] {cff1e111-849c-46ee-ac4b-022deaaf8d97} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1350, line 1353) (in query: SELECT toDecimal32([]);) 2025.07.13 02:39:33.123887 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal32([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.310462 [ 32979 ] {97046348-c321-4131-aba4-71cb1a692ef1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1351, line 1354) (in query: SELECT toDecimal32OrDefault([]);) 2025.07.13 02:39:33.324095 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal32OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.386163 [ 32979 ] {42ee38da-0068-4586-aaf7-55402f96372e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1352, line 1355) (in query: SELECT toDecimal32OrNull([]);) 2025.07.13 02:39:33.404623 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.503424 [ 32979 ] {334b84b1-f445-4004-b902-0fa2cf46abb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1353, line 1356) (in query: SELECT toDecimal32OrZero([]);) 2025.07.13 02:39:33.597488 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.638253 [ 32979 ] {a3d579e8-6cd0-44b1-aa25-66db3518810d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1354, line 1357) (in query: SELECT toDecimal64([]);) 2025.07.13 02:39:33.643572 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal64([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.674802 [ 32979 ] {b7602b6e-60cc-42f3-8d2a-ddbbe521ee5c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1355, line 1358) (in query: SELECT toDecimal64OrDefault([]);) 2025.07.13 02:39:33.681067 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal64OrDefault([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.738541 [ 32979 ] {2005535f-1a12-466b-bd07-a625a803b0d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1356, line 1359) (in query: SELECT toDecimal64OrNull([]);) 2025.07.13 02:39:33.743512 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.783006 [ 32979 ] {c38580e5-b4d7-4526-ab8f-f6c8b0f8f069} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1357, line 1360) (in query: SELECT toDecimal64OrZero([]);) 2025.07.13 02:39:33.786216 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.815011 [ 32979 ] {a544e817-54e8-4311-8beb-0e2aaaa72b3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1358, line 1361) (in query: SELECT toDecimalString([]);) 2025.07.13 02:39:33.819486 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.853809 [ 32979 ] {c44d940d-19e8-497c-82dc-0eedf1bd5c5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 1, should be 2: In scope SELECT toFixedString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1359, line 1362) (in query: SELECT toFixedString([]);) 2025.07.13 02:39:33.858347 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 1, should be 2: In scope SELECT toFixedString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:33.897826 [ 32979 ] {d74fe0ff-3053-4c09-847f-a11eaf4228e1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat32: In scope SELECT toFloat32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1360, line 1363) (in query: SELECT toFloat32([]);) 2025.07.13 02:39:33.904460 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat32: In scope SELECT toFloat32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:33.937036 [ 32979 ] {77c81375-6228-4fbc-890d-60131c4f60a5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat32: In scope SELECT toFloat32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1361, line 1364) (in query: SELECT toFloat32OrDefault([]);) 2025.07.13 02:39:33.942788 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat32: In scope SELECT toFloat32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:33.982843 [ 32979 ] {d1e125d8-ad65-4101-9f46-17f643a91e58} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1362, line 1365) (in query: SELECT toFloat32OrNull([]);) 2025.07.13 02:39:33.991988 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.051387 [ 32979 ] {cb759acc-4199-453f-ba4a-93444b0b412e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1363, line 1366) (in query: SELECT toFloat32OrZero([]);) 2025.07.13 02:39:34.058283 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.092186 [ 32979 ] {c651c951-18b2-4fc3-9241-77e077b8dc63} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat64: In scope SELECT toFloat64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1364, line 1367) (in query: SELECT toFloat64([]);) 2025.07.13 02:39:34.106566 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat64: In scope SELECT toFloat64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.153794 [ 32979 ] {1b8e1365-3216-415f-bf79-56ca4fc48024} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat64: In scope SELECT toFloat64OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1365, line 1368) (in query: SELECT toFloat64OrDefault([]);) 2025.07.13 02:39:34.158597 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toFloat64: In scope SELECT toFloat64OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.250807 [ 32979 ] {9e8475f1-9cc5-4cec-a5c0-e6e9c1102838} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1366, line 1369) (in query: SELECT toFloat64OrNull([]);) 2025.07.13 02:39:34.255685 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.292462 [ 32979 ] {efda6355-9489-45fc-803c-48587ea8085a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1367, line 1370) (in query: SELECT toFloat64OrZero([]);) 2025.07.13 02:39:34.298559 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.322066 [ 32979 ] {3c48a884-1437-4f88-a1b8-a69a97ceeec6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toHour([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1368, line 1371) (in query: SELECT toHour([]);) 2025.07.13 02:39:34.332386 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toHour([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.355788 [ 32979 ] {074222a9-9c63-41d9-b291-e8c705e6e8cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv4: In scope SELECT toIPv4([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1369, line 1372) (in query: SELECT toIPv4([]);) 2025.07.13 02:39:34.361099 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv4: In scope SELECT toIPv4([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.390427 [ 32979 ] {ad76b465-987c-476c-a29c-bbd2006a1a82} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv4: In scope SELECT toIPv4OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1370, line 1373) (in query: SELECT toIPv4OrDefault([]);) 2025.07.13 02:39:34.396164 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv4: In scope SELECT toIPv4OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.434229 [ 32979 ] {4a22d53f-02f5-4bdf-a384-3aba2b778352} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1371, line 1374) (in query: SELECT toIPv4OrNull([]);) 2025.07.13 02:39:34.438203 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.459589 [ 32979 ] {e1000027-6538-4523-9ba2-3e30273f6c38} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1372, line 1375) (in query: SELECT toIPv4OrZero([]);) 2025.07.13 02:39:34.463862 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.604111 [ 32979 ] {3a410817-4ad2-4f36-99b0-e85e0653be1b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv6: In scope SELECT toIPv6([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1373, line 1376) (in query: SELECT toIPv6([]);) 2025.07.13 02:39:34.615324 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv6: In scope SELECT toIPv6([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.654805 [ 32979 ] {742d91e7-5ffe-4003-aebe-bc52d30647ff} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv6: In scope SELECT toIPv6OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1374, line 1377) (in query: SELECT toIPv6OrDefault([]);) 2025.07.13 02:39:34.659598 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIPv6: In scope SELECT toIPv6OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.692951 [ 32979 ] {76d8e05d-0612-4068-b8f1-79053bc86e60} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1375, line 1378) (in query: SELECT toIPv6OrNull([]);) 2025.07.13 02:39:34.696896 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.717037 [ 32979 ] {8176fc07-fadd-4183-b4e2-76689d590150} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1376, line 1379) (in query: SELECT toIPv6OrZero([]);) 2025.07.13 02:39:34.720954 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.781528 [ 32979 ] {e65ea677-4ec3-4c9d-8b17-6164fb718a65} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOWeek. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1377, line 1380) (in query: SELECT toISOWeek([]);) 2025.07.13 02:39:34.786702 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOWeek. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.812204 [ 32979 ] {d58b65b8-5396-4327-81bc-e690efa210b7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1378, line 1381) (in query: SELECT toISOYear([]);) 2025.07.13 02:39:34.815871 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.876916 [ 32979 ] {5d1786ae-c8a1-42e4-8cec-709baa09ef46} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt128: In scope SELECT toInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1379, line 1382) (in query: SELECT toInt128([]);) 2025.07.13 02:39:34.882281 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt128: In scope SELECT toInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.915874 [ 32979 ] {ee3d4457-9b11-432c-a5bb-bf2ccd978efe} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt128: In scope SELECT toInt128OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1380, line 1383) (in query: SELECT toInt128OrDefault([]);) 2025.07.13 02:39:34.921798 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt128: In scope SELECT toInt128OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:34.970092 [ 32979 ] {790b46d0-1508-4532-8907-2ea5ac6c138f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1381, line 1384) (in query: SELECT toInt128OrNull([]);) 2025.07.13 02:39:34.975363 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.008855 [ 32979 ] {8b88d97c-76e3-42aa-9aba-4116472faf30} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1382, line 1385) (in query: SELECT toInt128OrZero([]);) 2025.07.13 02:39:35.015226 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.044633 [ 32979 ] {74052061-7256-4d2c-9ad5-840412b00a93} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt16: In scope SELECT toInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1383, line 1386) (in query: SELECT toInt16([]);) 2025.07.13 02:39:35.049762 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt16: In scope SELECT toInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.088111 [ 32979 ] {ba4cb29f-7690-4dd2-8c56-b2398ac69a18} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt16: In scope SELECT toInt16OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1384, line 1387) (in query: SELECT toInt16OrDefault([]);) 2025.07.13 02:39:35.093471 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt16: In scope SELECT toInt16OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.126941 [ 32979 ] {949f092e-3fe9-4acd-be4b-7a065bd122dc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1385, line 1388) (in query: SELECT toInt16OrNull([]);) 2025.07.13 02:39:35.132285 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.230999 [ 32979 ] {ea80ff6d-2e6d-4d5d-a92a-9e530e367bd2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1386, line 1389) (in query: SELECT toInt16OrZero([]);) 2025.07.13 02:39:35.245204 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.276009 [ 32979 ] {a502b41c-900c-4586-a428-9dd3ef675700} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt256: In scope SELECT toInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1387, line 1390) (in query: SELECT toInt256([]);) 2025.07.13 02:39:35.299012 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt256: In scope SELECT toInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.330077 [ 32979 ] {8263cb22-7f7e-4d62-a49f-5084bb07d4b2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt256: In scope SELECT toInt256OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1388, line 1391) (in query: SELECT toInt256OrDefault([]);) 2025.07.13 02:39:35.335731 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt256: In scope SELECT toInt256OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.366742 [ 32979 ] {b8fb2cdf-d8d6-4c30-8542-85fe16fddb43} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1389, line 1392) (in query: SELECT toInt256OrNull([]);) 2025.07.13 02:39:35.371846 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.414746 [ 32979 ] {c672bb17-84a9-450e-97cb-cc78fb3f2b72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1390, line 1393) (in query: SELECT toInt256OrZero([]);) 2025.07.13 02:39:35.420029 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.455400 [ 32979 ] {3904a9d5-7ab5-4178-82a0-156817fdae8c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt32: In scope SELECT toInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1391, line 1394) (in query: SELECT toInt32([]);) 2025.07.13 02:39:35.460733 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt32: In scope SELECT toInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.492546 [ 32979 ] {39441747-eae0-4871-9a01-5e3cbbc384a6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt32: In scope SELECT toInt32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1392, line 1395) (in query: SELECT toInt32OrDefault([]);) 2025.07.13 02:39:35.498129 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt32: In scope SELECT toInt32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.624682 [ 32979 ] {8fb0454f-796e-41b6-814f-3fed36cc9b93} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1393, line 1396) (in query: SELECT toInt32OrNull([]);) 2025.07.13 02:39:35.629808 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.751339 [ 32979 ] {7485a012-febe-4eea-9f7e-f1daa80b1900} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1394, line 1397) (in query: SELECT toInt32OrZero([]);) 2025.07.13 02:39:35.756869 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.898533 [ 32979 ] {3d726312-4e4e-43aa-9a57-786aa796bd6c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt64: In scope SELECT toInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1395, line 1398) (in query: SELECT toInt64([]);) 2025.07.13 02:39:35.914098 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt64: In scope SELECT toInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:35.963590 [ 32979 ] {b2ed996a-b38a-4058-a6f2-d770f8b9ede3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt64: In scope SELECT toInt64OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1396, line 1399) (in query: SELECT toInt64OrDefault([]);) 2025.07.13 02:39:35.968228 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt64: In scope SELECT toInt64OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.011215 [ 32979 ] {11c74700-a570-4d7e-8a6a-ae1d24e67859} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1397, line 1400) (in query: SELECT toInt64OrNull([]);) 2025.07.13 02:39:36.015034 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.039949 [ 32979 ] {05818f8e-7e79-4f8e-8c11-099e08dc5d5c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1398, line 1401) (in query: SELECT toInt64OrZero([]);) 2025.07.13 02:39:36.044696 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.070703 [ 32979 ] {4aefa3b7-736b-420c-b3cc-20108d43ef83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt8: In scope SELECT toInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1399, line 1402) (in query: SELECT toInt8([]);) 2025.07.13 02:39:36.075607 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt8: In scope SELECT toInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.110190 [ 32979 ] {58c96bd7-5a45-4c23-84b7-60ddc7aed842} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt8: In scope SELECT toInt8OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1400, line 1403) (in query: SELECT toInt8OrDefault([]);) 2025.07.13 02:39:36.115597 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toInt8: In scope SELECT toInt8OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.180295 [ 32979 ] {d1a84ea2-4a9d-40c5-9de1-19dd1c970479} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1401, line 1404) (in query: SELECT toInt8OrNull([]);) 2025.07.13 02:39:36.204960 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.234585 [ 32979 ] {de94a479-4c08-4e30-9c57-cd333ce2fdcd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1402, line 1405) (in query: SELECT toInt8OrZero([]);) 2025.07.13 02:39:36.239479 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.264340 [ 32979 ] {daa29bd7-826f-4325-a77f-d40fb83360f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalDay: In scope SELECT toIntervalDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1403, line 1406) (in query: SELECT toIntervalDay([]);) 2025.07.13 02:39:36.268783 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalDay: In scope SELECT toIntervalDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.311554 [ 32979 ] {34d1bdbf-105b-414e-b011-f724ad4cf88a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalHour: In scope SELECT toIntervalHour([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1404, line 1407) (in query: SELECT toIntervalHour([]);) 2025.07.13 02:39:36.317313 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalHour: In scope SELECT toIntervalHour([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.353031 [ 32979 ] {43ae9c46-2da1-4480-b63e-e31dede86419} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMicrosecond: In scope SELECT toIntervalMicrosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1405, line 1408) (in query: SELECT toIntervalMicrosecond([]);) 2025.07.13 02:39:36.358327 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMicrosecond: In scope SELECT toIntervalMicrosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.395606 [ 32979 ] {bf8b60b2-6b96-43a5-9d6c-21959b1c90a8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMillisecond: In scope SELECT toIntervalMillisecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1406, line 1409) (in query: SELECT toIntervalMillisecond([]);) 2025.07.13 02:39:36.400704 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMillisecond: In scope SELECT toIntervalMillisecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.434265 [ 32979 ] {a1c2d288-e7ce-4d14-a2f1-684f717f930f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMinute: In scope SELECT toIntervalMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1407, line 1410) (in query: SELECT toIntervalMinute([]);) 2025.07.13 02:39:36.439290 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMinute: In scope SELECT toIntervalMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.475708 [ 32979 ] {c9f8ef43-8225-48ee-ae80-b59619b52407} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMonth: In scope SELECT toIntervalMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1408, line 1411) (in query: SELECT toIntervalMonth([]);) 2025.07.13 02:39:36.480632 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalMonth: In scope SELECT toIntervalMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.506498 [ 32979 ] {68f73ac4-59d0-4adb-9a75-f7b51ef0c6f3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalNanosecond: In scope SELECT toIntervalNanosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1409, line 1412) (in query: SELECT toIntervalNanosecond([]);) 2025.07.13 02:39:36.511612 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalNanosecond: In scope SELECT toIntervalNanosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.598370 [ 32979 ] {63cbe9ea-047a-4c0b-9749-e1925546ed51} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalQuarter: In scope SELECT toIntervalQuarter([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1410, line 1413) (in query: SELECT toIntervalQuarter([]);) 2025.07.13 02:39:36.602668 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalQuarter: In scope SELECT toIntervalQuarter([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.646548 [ 32979 ] {160dfbe2-7e5a-485e-bae8-e3740ec112a0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalSecond: In scope SELECT toIntervalSecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1411, line 1414) (in query: SELECT toIntervalSecond([]);) 2025.07.13 02:39:36.659887 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalSecond: In scope SELECT toIntervalSecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.733398 [ 32979 ] {b072a749-d2e9-4244-8069-8fb3aca1e2aa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalWeek: In scope SELECT toIntervalWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1412, line 1415) (in query: SELECT toIntervalWeek([]);) 2025.07.13 02:39:36.739336 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalWeek: In scope SELECT toIntervalWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.768882 [ 32979 ] {ad30f138-be68-48f4-ab1a-0c9768efc670} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalYear: In scope SELECT toIntervalYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1413, line 1416) (in query: SELECT toIntervalYear([]);) 2025.07.13 02:39:36.774608 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toIntervalYear: In scope SELECT toIntervalYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:36.990822 [ 32979 ] {d6fdaf4e-c502-4335-a631-92cbdee74cc3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1415, line 1418) (in query: SELECT toLastDayOfMonth([]);) 2025.07.13 02:39:36.994787 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.031203 [ 32979 ] {c5739699-b096-416b-b490-b18b8403c9a0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toLastDayOfWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1416, line 1419) (in query: SELECT toLastDayOfWeek([]);) 2025.07.13 02:39:37.036830 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toLastDayOfWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.064693 [ 32979 ] {47e3d122-0b5c-4832-a0bb-ab0fe4168fac} executeQuery: Code: 43. DB::Exception: DataTypeLowCardinality is supported only for numbers, strings, Date or DateTime, but got Array(Nothing): In scope SELECT toLowCardinality([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1417, line 1420) (in query: SELECT toLowCardinality([]);) 2025.07.13 02:39:37.069007 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: DataTypeLowCardinality is supported only for numbers, strings, Date or DateTime, but got Array(Nothing): In scope SELECT toLowCardinality([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.190025 [ 32979 ] {93f356a7-c089-49fd-9957-c4dbf7bd191d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1418, line 1421) (in query: SELECT toMillisecond([]);) 2025.07.13 02:39:37.196747 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.253664 [ 32979 ] {10fa8033-f920-4661-8e9b-cd547935de9e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1419, line 1422) (in query: SELECT toMinute([]);) 2025.07.13 02:39:37.270167 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.335364 [ 32979 ] {87bc3f9f-b3e9-4217-b2a3-6074fcb815b3} executeQuery: Code: 43. DB::Exception: The argument of function toModifiedJulianDay must be String or FixedString: In scope SELECT toModifiedJulianDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1420, line 1423) (in query: SELECT toModifiedJulianDay([]);) 2025.07.13 02:39:37.347806 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function toModifiedJulianDay must be String or FixedString: In scope SELECT toModifiedJulianDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.428850 [ 32979 ] {eeeb1684-b313-4e0d-b51b-65ba4eb05dbe} executeQuery: Code: 43. DB::Exception: The argument of function toModifiedJulianDayOrNull must be String or FixedString: In scope SELECT toModifiedJulianDayOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1421, line 1424) (in query: SELECT toModifiedJulianDayOrNull([]);) 2025.07.13 02:39:37.433486 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function toModifiedJulianDayOrNull must be String or FixedString: In scope SELECT toModifiedJulianDayOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.539740 [ 32979 ] {52ff6468-25a9-4f70-86a2-8443fe590cf3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonday. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonday([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1422, line 1425) (in query: SELECT toMonday([]);) 2025.07.13 02:39:37.542642 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonday. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonday([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.557727 [ 32979 ] {7590e27f-694c-44c8-ba88-1430d2bcc554} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1423, line 1426) (in query: SELECT toMonth([]);) 2025.07.13 02:39:37.560353 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.577969 [ 32979 ] {eecdca84-e74a-4c18-8386-701cf0f81bba} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonthNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonthNumSinceEpoch([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1424, line 1427) (in query: SELECT toMonthNumSinceEpoch([]);) 2025.07.13 02:39:37.581006 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonthNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonthNumSinceEpoch([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.597141 [ 32979 ] {e4244f4d-389c-4c81-888e-c013c8e6497f} executeQuery: Code: 43. DB::Exception: Nested type Array(Nothing) cannot be inside Nullable type: In scope SELECT toNullable([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1425, line 1428) (in query: SELECT toNullable([]);) 2025.07.13 02:39:37.600178 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Array(Nothing) cannot be inside Nullable type: In scope SELECT toNullable([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.631420 [ 32979 ] {36ae9ae9-b4ff-489e-bf50-e6675b37eca2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toQuarter([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1426, line 1429) (in query: SELECT toQuarter([]);) 2025.07.13 02:39:37.637057 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toQuarter([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.706154 [ 32979 ] {be85555b-babb-4d64-abcc-eede0f6f2c8a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeDayNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeDayNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1427, line 1430) (in query: SELECT toRelativeDayNum([]);) 2025.07.13 02:39:37.709419 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeDayNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeDayNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.728456 [ 32979 ] {2cacffc0-7b89-40b6-81a8-f9c71d9a9b23} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeHourNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeHourNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1428, line 1431) (in query: SELECT toRelativeHourNum([]);) 2025.07.13 02:39:37.733478 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeHourNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeHourNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.760781 [ 32979 ] {e25c0969-33b2-4f07-b475-4f310228f963} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMinuteNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMinuteNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1429, line 1432) (in query: SELECT toRelativeMinuteNum([]);) 2025.07.13 02:39:37.765468 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMinuteNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMinuteNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.813891 [ 32979 ] {592ed59a-c5a8-4f58-bdd8-c86898cf3d01} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMonthNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMonthNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1430, line 1433) (in query: SELECT toRelativeMonthNum([]);) 2025.07.13 02:39:37.817253 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMonthNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMonthNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.844260 [ 32979 ] {42220d34-89c7-4d29-b28c-e54ec9e68489} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeQuarterNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeQuarterNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1431, line 1434) (in query: SELECT toRelativeQuarterNum([]);) 2025.07.13 02:39:37.848935 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeQuarterNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeQuarterNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:37.955592 [ 32979 ] {e60a4571-2820-4b87-bfa5-e30d667ce6c9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeSecondNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeSecondNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1432, line 1435) (in query: SELECT toRelativeSecondNum([]);) 2025.07.13 02:39:37.975863 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeSecondNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeSecondNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.014575 [ 32979 ] {524f9639-02ad-40e9-9ab0-fa101c3144c0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeWeekNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeWeekNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1433, line 1436) (in query: SELECT toRelativeWeekNum([]);) 2025.07.13 02:39:38.017873 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeWeekNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeWeekNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.057492 [ 32979 ] {426a4025-1f65-4bd1-958d-0df6772a945e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeYearNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeYearNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1434, line 1437) (in query: SELECT toRelativeYearNum([]);) 2025.07.13 02:39:38.063678 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeYearNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeYearNum([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.094181 [ 32979 ] {1112c5d1-4c8a-4b65-87fb-43a806e2c3c9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toSecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1435, line 1438) (in query: SELECT toSecond([]);) 2025.07.13 02:39:38.102792 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toSecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.148137 [ 32979 ] {b3a611dc-37f8-4f63-a31a-dc9dba2b64dc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfDay. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1436, line 1439) (in query: SELECT toStartOfDay([]);) 2025.07.13 02:39:38.153993 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfDay. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfDay([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.180585 [ 32979 ] {2d56cd91-9cf5-43b5-be8a-0ae3965bec8d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFifteenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFifteenMinutes([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1437, line 1440) (in query: SELECT toStartOfFifteenMinutes([]);) 2025.07.13 02:39:38.220881 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFifteenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFifteenMinutes([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.265383 [ 32979 ] {58964556-9d1a-408a-aab9-4924a1e4b6d6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1438, line 1441) (in query: SELECT toStartOfFiveMinute([]);) 2025.07.13 02:39:38.272684 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.301685 [ 32979 ] {eccc30ae-cf8e-4dca-9197-ccf88c9b1cd8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinutes([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1439, line 1442) (in query: SELECT toStartOfFiveMinutes([]);) 2025.07.13 02:39:38.307099 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinutes([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.409303 [ 32979 ] {33f7483c-ac1d-446b-8e6c-3f281836c008} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfHour([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1440, line 1443) (in query: SELECT toStartOfHour([]);) 2025.07.13 02:39:38.424271 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfHour([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.497413 [ 32979 ] {edf747cb-d92f-4ea3-8fdc-7259935103d5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfISOYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1441, line 1444) (in query: SELECT toStartOfISOYear([]);) 2025.07.13 02:39:38.502730 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfISOYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.542651 [ 32979 ] {fdd1aa98-7570-45b0-9d5b-2079ad69efca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT toStartOfInterval([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1442, line 1445) (in query: SELECT toStartOfInterval([]);) 2025.07.13 02:39:38.564354 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT toStartOfInterval([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:38.629164 [ 32979 ] {72c93654-f711-484f-bf2e-5df0ec6cc68a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMicrosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMicrosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1443, line 1446) (in query: SELECT toStartOfMicrosecond([]);) 2025.07.13 02:39:38.636024 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMicrosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMicrosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.691446 [ 32979 ] {edd7424b-9f5a-4f15-975e-4a8c1e62d506} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMillisecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1444, line 1447) (in query: SELECT toStartOfMillisecond([]);) 2025.07.13 02:39:38.697004 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMillisecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.772675 [ 32979 ] {58d12363-c922-4d36-83c4-1f9e01f87081} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1445, line 1448) (in query: SELECT toStartOfMinute([]);) 2025.07.13 02:39:38.791199 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMinute([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.886593 [ 32979 ] {61483add-6a84-47a2-a2b2-be57b5030f20} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1446, line 1449) (in query: SELECT toStartOfMonth([]);) 2025.07.13 02:39:38.892734 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMonth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.932580 [ 32979 ] {daa6f82b-f807-4dfb-8b3e-1401e426db6c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfNanosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfNanosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1447, line 1450) (in query: SELECT toStartOfNanosecond([]);) 2025.07.13 02:39:38.938420 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfNanosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfNanosecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:38.977975 [ 32979 ] {35047a58-dd76-4893-bd4a-8d4cebd55d83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfQuarter([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1448, line 1451) (in query: SELECT toStartOfQuarter([]);) 2025.07.13 02:39:38.986432 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfQuarter([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.056310 [ 32979 ] {99157b07-e2bc-403c-a455-c9a8d0f3b295} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1449, line 1452) (in query: SELECT toStartOfSecond([]);) 2025.07.13 02:39:39.060077 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.088618 [ 32979 ] {f36645d0-105a-446f-a323-fc352e72d471} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfTenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfTenMinutes([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1450, line 1453) (in query: SELECT toStartOfTenMinutes([]);) 2025.07.13 02:39:39.092589 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfTenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfTenMinutes([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.114016 [ 32979 ] {b0a8f17e-345c-4ab0-9ed6-4cd7e90ceb20} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toStartOfWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1451, line 1454) (in query: SELECT toStartOfWeek([]);) 2025.07.13 02:39:39.117328 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toStartOfWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.199481 [ 32979 ] {f174d6cd-55c1-4c27-8123-7293d5fd0269} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1452, line 1455) (in query: SELECT toStartOfYear([]);) 2025.07.13 02:39:39.205649 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.312275 [ 32979 ] {fe54e6b9-3d7e-4969-bc8c-6fcf900a211f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStringCutToZero: In scope SELECT toStringCutToZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1454, line 1457) (in query: SELECT toStringCutToZero([]);) 2025.07.13 02:39:39.317753 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStringCutToZero: In scope SELECT toStringCutToZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.347524 [ 32979 ] {30af3747-3caf-4e8e-8d2b-daeaff4c9f83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1455, line 1458) (in query: SELECT toTime([]);) 2025.07.13 02:39:39.352742 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toTime([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.391778 [ 32979 ] {23d32676-43a5-416d-8c34-64a7baf853c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimeZone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1456, line 1459) (in query: SELECT toTimeZone([]);) 2025.07.13 02:39:39.397189 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimeZone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:39.457594 [ 32979 ] {5efb327c-1142-4f56-a7b5-e8049b89bf61} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimezone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1457, line 1460) (in query: SELECT toTimezone([]);) 2025.07.13 02:39:39.464326 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimezone([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:39.618475 [ 32979 ] {3d87a10b-2585-499c-8186-29ec4ce782d5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt128: In scope SELECT toUInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1459, line 1462) (in query: SELECT toUInt128([]);) 2025.07.13 02:39:39.624725 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt128: In scope SELECT toUInt128([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.653302 [ 32979 ] {4b076149-094d-4717-a62c-abeaa2fb1425} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt128: In scope SELECT toUInt128OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1460, line 1463) (in query: SELECT toUInt128OrDefault([]);) 2025.07.13 02:39:39.658286 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt128: In scope SELECT toUInt128OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.782657 [ 32979 ] {ee3ee459-2cb4-4f55-999d-78b2816a5772} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1461, line 1464) (in query: SELECT toUInt128OrNull([]);) 2025.07.13 02:39:39.788049 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.818410 [ 32979 ] {0a4a36af-100b-4ff1-9aa2-9f377cae9487} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1462, line 1465) (in query: SELECT toUInt128OrZero([]);) 2025.07.13 02:39:39.823525 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.852046 [ 32979 ] {179e2435-7d40-40e4-92e7-1a69e540b63a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt16: In scope SELECT toUInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1463, line 1466) (in query: SELECT toUInt16([]);) 2025.07.13 02:39:39.859659 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt16: In scope SELECT toUInt16([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.896440 [ 32979 ] {e012a6f9-5f88-448d-ab1d-30e85fb7c115} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt16: In scope SELECT toUInt16OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1464, line 1467) (in query: SELECT toUInt16OrDefault([]);) 2025.07.13 02:39:39.902716 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt16: In scope SELECT toUInt16OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:39.998994 [ 32979 ] {ab46dfa6-5907-48e1-a01e-b00000e79cc1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1465, line 1468) (in query: SELECT toUInt16OrNull([]);) 2025.07.13 02:39:40.009728 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.042257 [ 32979 ] {53b1c048-53d5-45f0-a587-ec3ae37e54e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1466, line 1469) (in query: SELECT toUInt16OrZero([]);) 2025.07.13 02:39:40.048236 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.149345 [ 32979 ] {4fc1a3e3-05af-4848-9148-a187b12870ad} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt256: In scope SELECT toUInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1467, line 1470) (in query: SELECT toUInt256([]);) 2025.07.13 02:39:40.163934 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt256: In scope SELECT toUInt256([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.332903 [ 32979 ] {46aeb809-0ecc-4c02-943e-8718ac1ee352} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt256: In scope SELECT toUInt256OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1468, line 1471) (in query: SELECT toUInt256OrDefault([]);) 2025.07.13 02:39:40.339257 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt256: In scope SELECT toUInt256OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.390272 [ 32979 ] {05ddfc38-991d-44cf-a91f-d8c11e8124a2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1469, line 1472) (in query: SELECT toUInt256OrNull([]);) 2025.07.13 02:39:40.403362 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.449232 [ 32979 ] {aea30798-55a3-44c1-9ac9-521d6de37dee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1470, line 1473) (in query: SELECT toUInt256OrZero([]);) 2025.07.13 02:39:40.533124 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.554596 [ 32979 ] {67a8396b-da9f-43c0-b56e-5090b61cce06} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt32: In scope SELECT toUInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1471, line 1474) (in query: SELECT toUInt32([]);) 2025.07.13 02:39:40.558408 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt32: In scope SELECT toUInt32([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.581415 [ 32979 ] {02ab1810-59cc-4162-9ac7-ae68acee62ed} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt32: In scope SELECT toUInt32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1472, line 1475) (in query: SELECT toUInt32OrDefault([]);) 2025.07.13 02:39:40.618886 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt32: In scope SELECT toUInt32OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.644169 [ 32979 ] {c99f9dc3-d8ce-477d-a577-6d8a14d8b574} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1473, line 1476) (in query: SELECT toUInt32OrNull([]);) 2025.07.13 02:39:40.648955 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.674964 [ 32979 ] {a6fa3c9f-1d35-4ab2-8db1-09532b7b362e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1474, line 1477) (in query: SELECT toUInt32OrZero([]);) 2025.07.13 02:39:40.679835 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.713576 [ 32979 ] {f0b39225-8f98-48c6-bb36-60e1d12047b0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt64: In scope SELECT toUInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1475, line 1478) (in query: SELECT toUInt64([]);) 2025.07.13 02:39:40.719428 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt64: In scope SELECT toUInt64([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.763906 [ 32979 ] {f281ff6e-722d-42d5-a611-1df138d7c97b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt64: In scope SELECT toUInt64OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1476, line 1479) (in query: SELECT toUInt64OrDefault([]);) 2025.07.13 02:39:40.777866 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt64: In scope SELECT toUInt64OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.811201 [ 32979 ] {ffd15198-68e5-43a4-a1aa-14ac30f72d61} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1477, line 1480) (in query: SELECT toUInt64OrNull([]);) 2025.07.13 02:39:40.816107 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.844082 [ 32979 ] {bc2f7a18-36fb-4e90-b627-93ca5a9561be} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1478, line 1481) (in query: SELECT toUInt64OrZero([]);) 2025.07.13 02:39:40.849468 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.943749 [ 32979 ] {4fdf6596-58c1-435d-8d14-1294dd49ce2c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt8: In scope SELECT toUInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1479, line 1482) (in query: SELECT toUInt8([]);) 2025.07.13 02:39:40.949670 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt8: In scope SELECT toUInt8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:40.984147 [ 32979 ] {45255387-3277-49b3-a5b6-3e539741fa77} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt8: In scope SELECT toUInt8OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1480, line 1483) (in query: SELECT toUInt8OrDefault([]);) 2025.07.13 02:39:40.990007 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt8: In scope SELECT toUInt8OrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.022280 [ 32979 ] {527bcec0-39af-4ea2-a3ae-6a511e715981} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1481, line 1484) (in query: SELECT toUInt8OrNull([]);) 2025.07.13 02:39:41.028400 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.069019 [ 32979 ] {b08d8368-a048-4075-9515-687deb1d020f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1482, line 1485) (in query: SELECT toUInt8OrZero([]);) 2025.07.13 02:39:41.074408 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.118511 [ 32979 ] {748756e0-906a-4b85-8153-4e8ed3b54f2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT toUTCTimestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1483, line 1486) (in query: SELECT toUTCTimestamp([]);) 2025.07.13 02:39:41.123815 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT toUTCTimestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:41.154956 [ 32979 ] {03179f25-273b-4dbe-9c93-d45bc4e1b17c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUUID: In scope SELECT toUUID([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1484, line 1487) (in query: SELECT toUUID([]);) 2025.07.13 02:39:41.160605 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUUID: In scope SELECT toUUID([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.188780 [ 32979 ] {ade9e384-bc95-4423-b074-041b2694d586} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUUID: In scope SELECT toUUIDOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1485, line 1488) (in query: SELECT toUUIDOrDefault([]);) 2025.07.13 02:39:41.193721 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUUID: In scope SELECT toUUIDOrDefault([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.382928 [ 32979 ] {9ea20318-54f5-42b5-9056-ca0a258b5724} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1486, line 1489) (in query: SELECT toUUIDOrNull([]);) 2025.07.13 02:39:41.386042 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrNull([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.410903 [ 32979 ] {8fadf370-1eb8-4163-a07d-c2003e055f23} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1487, line 1490) (in query: SELECT toUUIDOrZero([]);) 2025.07.13 02:39:41.414090 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrZero([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.460043 [ 32979 ] {333083ac-78f0-4488-afa2-de760dab54cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUnixTimestamp: In scope SELECT toUnixTimestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1488, line 1491) (in query: SELECT toUnixTimestamp([]);) 2025.07.13 02:39:41.563214 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUnixTimestamp: In scope SELECT toUnixTimestamp([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.601221 [ 32979 ] {e6a9982b-ba07-4ac1-adf1-cf106e4ff175} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Micro([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1489, line 1492) (in query: SELECT toUnixTimestamp64Micro([]);) 2025.07.13 02:39:41.605665 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Micro([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.628151 [ 32979 ] {e2ca59ba-4a6e-4c20-81f7-ec6f29cd58f3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Milli([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1490, line 1493) (in query: SELECT toUnixTimestamp64Milli([]);) 2025.07.13 02:39:41.632116 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Milli([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.653107 [ 32979 ] {a9caae05-86c8-495c-8b73-68ed83ec2aba} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Nano([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Nano([]);) 2025.07.13 02:39:41.656792 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Nano([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.680165 [ 32979 ] {c8895171-ab7d-425a-ad00-021f47fc5c28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Second([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Second([]);) 2025.07.13 02:39:41.685234 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: Array(Nothing): In scope SELECT toUnixTimestamp64Second([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.719820 [ 32979 ] {b3985b40-1027-4662-999a-bd33bf0951ab} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toValidUTF8: In scope SELECT toValidUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1493, line 1496) (in query: SELECT toValidUTF8([]);) 2025.07.13 02:39:41.729841 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toValidUTF8: In scope SELECT toValidUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.762609 [ 32979 ] {6c1f3467-3234-4704-b291-50f584767a18} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1494, line 1497) (in query: SELECT toWeek([]);) 2025.07.13 02:39:41.767159 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.808958 [ 32979 ] {8ca53ad4-238b-4dfb-956b-fb08bdd8078a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMM([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1495, line 1498) (in query: SELECT toYYYYMM([]);) 2025.07.13 02:39:41.815723 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMM([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.862938 [ 32979 ] {7093ed2f-0b87-4e1e-ba15-473952bceb17} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDD. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDD([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1496, line 1499) (in query: SELECT toYYYYMMDD([]);) 2025.07.13 02:39:41.867397 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDD. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDD([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.895125 [ 32979 ] {1aeba4ed-1014-48f3-85b9-38fc5f5124af} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDDhhmmss. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDDhhmmss([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1497, line 1500) (in query: SELECT toYYYYMMDDhhmmss([]);) 2025.07.13 02:39:41.900334 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDDhhmmss. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDDhhmmss([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.937032 [ 32979 ] {f7cf0712-fbd6-4785-b14e-c3f73c9a7a1b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1498, line 1501) (in query: SELECT toYear([]);) 2025.07.13 02:39:41.942219 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYear([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:41.969045 [ 32979 ] {6d09d7b1-797a-4cab-b07b-a1a90440af4b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYearNumSinceEpoch([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1499, line 1502) (in query: SELECT toYearNumSinceEpoch([]);) 2025.07.13 02:39:41.974865 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYearNumSinceEpoch([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.012967 [ 32979 ] {20fb6c93-f208-4f7e-a330-d5dc57302334} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toYearWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1500, line 1503) (in query: SELECT toYearWeek([]);) 2025.07.13 02:39:42.018121 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toYearWeek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.054706 [ 32979 ] {b7e90113-0011-42e4-92f0-5fbb0ddca53e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT to_utc_timestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1501, line 1504) (in query: SELECT to_utc_timestamp([]);) 2025.07.13 02:39:42.059859 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT to_utc_timestamp([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.095426 [ 32979 ] {3273e946-fd38-4363-a739-0d8d6bbcaec6} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT today([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1502, line 1505) (in query: SELECT today([]);) 2025.07.13 02:39:42.099842 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT today([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.125577 [ 32979 ] {3be42d43-ee56-4a64-bc7c-bf7d4f6063b1} executeQuery: Code: 36. DB::Exception: Function tokens first argument type should be String or FixedString. Actual Array(Nothing): In scope SELECT tokens([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1503, line 1506) (in query: SELECT tokens([]);) 2025.07.13 02:39:42.130294 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Function tokens first argument type should be String or FixedString. Actual Array(Nothing): In scope SELECT tokens([]). (BAD_ARGUMENTS) 2025.07.13 02:39:42.278783 [ 32979 ] {31ee7a25-15b9-4afa-9e21-8969d18addfd} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1505, line 1508) (in query: SELECT topKWeighted([]);) 2025.07.13 02:39:42.284448 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.313215 [ 32979 ] {5debe51e-8614-4854-bd79-d6e892946476} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function topLevelDomain: In scope SELECT topLevelDomain([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1506, line 1509) (in query: SELECT topLevelDomain([]);) 2025.07.13 02:39:42.318221 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function topLevelDomain: In scope SELECT topLevelDomain([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.344038 [ 32979 ] {cae92969-acb1-42f7-aa05-1caaa4d4fa9b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function topLevelDomainRFC: In scope SELECT topLevelDomainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1507, line 1510) (in query: SELECT topLevelDomainRFC([]);) 2025.07.13 02:39:42.347228 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function topLevelDomainRFC: In scope SELECT topLevelDomainRFC([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.369974 [ 32979 ] {5d01aa7f-6827-438d-9132-ccdcc5c5cd88} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 1, should be 0: In scope SELECT transactionID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1508, line 1511) (in query: SELECT transactionID([]);) 2025.07.13 02:39:42.373878 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 1, should be 0: In scope SELECT transactionID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.407636 [ 32979 ] {e2da414b-01e1-4f3c-b805-97cfe2fe2fa2} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionLatestSnapshot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1509, line 1512) (in query: SELECT transactionLatestSnapshot([]);) 2025.07.13 02:39:42.412892 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionLatestSnapshot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.438731 [ 32979 ] {11e589ba-548e-4b9a-b8e2-b021118acc71} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionOldestSnapshot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1510, line 1513) (in query: SELECT transactionOldestSnapshot([]);) 2025.07.13 02:39:42.443674 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionOldestSnapshot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.498350 [ 32979 ] {267b2fcd-795d-4cc8-a786-b4962b224481} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 1, should be 3 or 4: In scope SELECT transform([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1511, line 1514) (in query: SELECT transform([]);) 2025.07.13 02:39:42.503794 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 1, should be 3 or 4: In scope SELECT transform([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.532415 [ 32979 ] {a6795de7-ab35-40c0-b7cc-dbba55eb6628} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 1, should be 3: In scope SELECT translate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1512, line 1515) (in query: SELECT translate([]);) 2025.07.13 02:39:42.537345 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 1, should be 3: In scope SELECT translate([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.566223 [ 32979 ] {90dc157a-e71d-4347-91d3-86833be8b087} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 1, should be 3: In scope SELECT translateUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1513, line 1516) (in query: SELECT translateUTF8([]);) 2025.07.13 02:39:42.571269 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 1, should be 3: In scope SELECT translateUTF8([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:42.598361 [ 32979 ] {e5f1be2c-df33-459a-801e-f52ad769eb4d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Array(Nothing): In scope SELECT trimBoth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1514, line 1517) (in query: SELECT trim([]);) 2025.07.13 02:39:42.612915 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Array(Nothing): In scope SELECT trimBoth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.642641 [ 32979 ] {6b3791f0-5218-4974-b7b2-53c4c2aff1ad} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Array(Nothing): In scope SELECT trimBoth([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1515, line 1518) (in query: SELECT trimBoth([]);) 2025.07.13 02:39:42.647897 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Array(Nothing): In scope SELECT trimBoth([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.673946 [ 32979 ] {783019ee-803c-4357-ae26-5c0e3118c466} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Array(Nothing): In scope SELECT trimLeft([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1516, line 1519) (in query: SELECT trimLeft([]);) 2025.07.13 02:39:42.728879 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Array(Nothing): In scope SELECT trimLeft([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.754495 [ 32979 ] {11b56d86-683d-415d-9332-804e862e5cd6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Array(Nothing): In scope SELECT trimRight([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1517, line 1520) (in query: SELECT trimRight([]);) 2025.07.13 02:39:42.759495 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Array(Nothing): In scope SELECT trimRight([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.787970 [ 32979 ] {1ccbdb0e-b4f1-4bc2-9b39-336db87beb66} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT trunc([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1518, line 1521) (in query: SELECT trunc([]);) 2025.07.13 02:39:42.792903 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT trunc([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.824414 [ 32979 ] {65175088-384e-4286-8e05-e5d8799c5bc7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT truncate([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1519, line 1522) (in query: SELECT truncate([]);) 2025.07.13 02:39:42.828935 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT truncate([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.893791 [ 32979 ] {480c17c3-e3c8-46bd-8d99-254083df5fac} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'tryBase58Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT tryBase58Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1520, line 1523) (in query: SELECT tryBase58Decode([]);) 2025.07.13 02:39:42.899140 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'tryBase58Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT tryBase58Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:42.952431 [ 32979 ] {81a722fc-0249-4362-8f4f-5770ceaebe1e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT tryBase64Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1521, line 1524) (in query: SELECT tryBase64Decode([]);) 2025.07.13 02:39:42.964336 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64Decode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT tryBase64Decode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:43.009111 [ 32979 ] {92657474-e6c0-4e9a-8d84-253cc95913e0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64URLDecode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT tryBase64URLDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1522, line 1525) (in query: SELECT tryBase64URLDecode([]);) 2025.07.13 02:39:43.016748 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64URLDecode'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT tryBase64URLDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:43.050408 [ 32979 ] {d0b60dfb-f018-479c-b9b9-474a572c0d41} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT tryDecrypt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1523, line 1526) (in query: SELECT tryDecrypt([]);) 2025.07.13 02:39:43.056546 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT tryDecrypt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.082587 [ 32979 ] {44e65874-d668-4b97-8563-7046dc0514b2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tryIdnaEncode: In scope SELECT tryIdnaEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1524, line 1527) (in query: SELECT tryIdnaEncode([]);) 2025.07.13 02:39:43.087536 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tryIdnaEncode: In scope SELECT tryIdnaEncode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:43.123378 [ 32979 ] {bcccaf95-6b1c-4a3e-85fb-268d001ec081} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1525, line 1528) (in query: SELECT tryPunycodeDecode([]);) 2025.07.13 02:39:43.148450 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:43.200929 [ 32979 ] {2e7097bf-0b96-4093-89bf-21d7473cb6e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 1, should be 2 or 3: In scope SELECT tumble([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1526, line 1529) (in query: SELECT tumble([]);) 2025.07.13 02:39:43.210849 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 1, should be 2 or 3: In scope SELECT tumble([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.250273 [ 32979 ] {7ee35ba3-f7ab-485f-8cc1-ad3433cf9c33} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function tumbleEnd should be DateTime, Tuple or UInt32: In scope SELECT tumbleEnd([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1527, line 1530) (in query: SELECT tumbleEnd([]);) 2025.07.13 02:39:43.256071 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function tumbleEnd should be DateTime, Tuple or UInt32: In scope SELECT tumbleEnd([]). (ILLEGAL_COLUMN) 2025.07.13 02:39:43.285745 [ 32979 ] {8faeda83-74fd-4c26-90ed-42119885c622} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function tumbleStart should be DateTime, Tuple or UInt32: In scope SELECT tumbleStart([]). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1528, line 1531) (in query: SELECT tumbleStart([]);) 2025.07.13 02:39:43.290353 [ 32979 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function tumbleStart should be DateTime, Tuple or UInt32: In scope SELECT tumbleStart([]). (ILLEGAL_COLUMN) 2025.07.13 02:39:43.426887 [ 32979 ] {fb6f139b-2f56-47ae-9499-9a7328740a32} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1530, line 1533) (in query: SELECT tupleConcat([]);) 2025.07.13 02:39:43.429941 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:43.447442 [ 32979 ] {4e1f3d2f-dde4-42b1-b1d5-55345dca3527} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 1, should be 2: In scope SELECT tupleDivide([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1531, line 1534) (in query: SELECT tupleDivide([]);) 2025.07.13 02:39:43.450627 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 1, should be 2: In scope SELECT tupleDivide([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.470548 [ 32979 ] {90cbe628-0928-4cf8-be7f-dcb087da7e7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleDivideByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1532, line 1535) (in query: SELECT tupleDivideByNumber([]);) 2025.07.13 02:39:43.473911 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleDivideByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.559413 [ 32979 ] {7c048fc9-170a-40d4-b5ae-f17ed6d89332} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1533, line 1536) (in query: SELECT tupleElement([]);) 2025.07.13 02:39:43.564354 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.672678 [ 32979 ] {2ba988ac-f6be-4d89-8a64-6b05be605406} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 1, should be 2: In scope SELECT tupleHammingDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1534, line 1537) (in query: SELECT tupleHammingDistance([]);) 2025.07.13 02:39:43.684672 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 1, should be 2: In scope SELECT tupleHammingDistance([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.723455 [ 32979 ] {c27b9951-d635-4cfa-ab8a-782f33da1539} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 1, should be 2: In scope SELECT tupleIntDiv([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1535, line 1538) (in query: SELECT tupleIntDiv([]);) 2025.07.13 02:39:43.728150 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 1, should be 2: In scope SELECT tupleIntDiv([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.837000 [ 32979 ] {4653cc68-8fe3-4f05-a2af-1d092a2d3f4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1536, line 1539) (in query: SELECT tupleIntDivByNumber([]);) 2025.07.13 02:39:43.841494 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.915279 [ 32979 ] {3639c373-cd58-4d49-a85b-5715d6d19024} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1537, line 1540) (in query: SELECT tupleIntDivOrZero([]);) 2025.07.13 02:39:43.929238 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZero([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:43.964246 [ 32979 ] {7095ae40-d515-4d41-86eb-d39cea1ec248} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1538, line 1541) (in query: SELECT tupleIntDivOrZeroByNumber([]);) 2025.07.13 02:39:43.968735 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.072978 [ 32979 ] {273d6917-f999-4091-b490-4e826a6b3651} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT tupleMinus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1539, line 1542) (in query: SELECT tupleMinus([]);) 2025.07.13 02:39:44.076850 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT tupleMinus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.100002 [ 32979 ] {b36320f6-5aaa-46ae-ad99-227e655200b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 1, should be 2: In scope SELECT tupleModulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1540, line 1543) (in query: SELECT tupleModulo([]);) 2025.07.13 02:39:44.104067 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 1, should be 2: In scope SELECT tupleModulo([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.129262 [ 32979 ] {787212e5-0f70-4ae2-99e3-d18b671360a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleModuloByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1541, line 1544) (in query: SELECT tupleModuloByNumber([]);) 2025.07.13 02:39:44.133675 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleModuloByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.168853 [ 32979 ] {a2cf9dcc-751b-4797-8bb2-5264024aa037} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 1, should be 2: In scope SELECT tupleMultiply([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1542, line 1545) (in query: SELECT tupleMultiply([]);) 2025.07.13 02:39:44.174228 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 1, should be 2: In scope SELECT tupleMultiply([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.254716 [ 32979 ] {35761952-f840-4c10-b1b5-678a52497545} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleMultiplyByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1543, line 1546) (in query: SELECT tupleMultiplyByNumber([]);) 2025.07.13 02:39:44.275608 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleMultiplyByNumber([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.328542 [ 32979 ] {1f53859e-9c59-4e41-b724-b8e6a3b6d199} executeQuery: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1544, line 1547) (in query: SELECT tupleNames([]);) 2025.07.13 02:39:44.334480 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:44.398022 [ 32979 ] {33588c6f-f7de-4818-8755-b18c62603ac1} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleNegate should be tuple, got Array(Nothing): In scope SELECT tupleNegate([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1545, line 1548) (in query: SELECT tupleNegate([]);) 2025.07.13 02:39:44.401385 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleNegate should be tuple, got Array(Nothing): In scope SELECT tupleNegate([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:44.426883 [ 32979 ] {dcbbe7e2-009d-4a3c-bb38-e8c72fcb0f59} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT tuplePlus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1546, line 1549) (in query: SELECT tuplePlus([]);) 2025.07.13 02:39:44.429528 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT tuplePlus([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:44.446793 [ 32979 ] {9f7ad1e1-2f52-460c-abd1-34f5e85158dd} executeQuery: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1547, line 1550) (in query: SELECT tupleToNameValuePairs([]);) 2025.07.13 02:39:44.450056 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:44.483809 [ 32979 ] {ffa32da3-6625-4d27-8093-509f5dbf0abf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function upper: In scope SELECT ucase([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1548, line 1551) (in query: SELECT ucase([]);) 2025.07.13 02:39:44.486955 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function upper: In scope SELECT ucase([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:44.505042 [ 32979 ] {5b4e473c-7d39-410e-983e-beacc9795b30} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function unbin: In scope SELECT unbin([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1549, line 1552) (in query: SELECT unbin([]);) 2025.07.13 02:39:44.508121 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function unbin: In scope SELECT unbin([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:44.543016 [ 32979 ] {78e2d797-05a5-460e-b1ab-84b9dbc495cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function unhex: In scope SELECT unhex([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1550, line 1553) (in query: SELECT unhex([]);) 2025.07.13 02:39:44.547003 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function unhex: In scope SELECT unhex([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:45.146996 [ 32979 ] {0fe64e56-52f9-48c1-a656-62db48693158} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 1, should be 2: In scope SELECT uniqThetaIntersect([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1557, line 1560) (in query: SELECT uniqThetaIntersect([]);) 2025.07.13 02:39:45.152652 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 1, should be 2: In scope SELECT uniqThetaIntersect([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:45.187328 [ 32979 ] {951f6819-b5d4-4d5d-bcb8-46ebbc63d39e} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 1, should be 2: In scope SELECT uniqThetaNot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1558, line 1561) (in query: SELECT uniqThetaNot([]);) 2025.07.13 02:39:45.281485 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 1, should be 2: In scope SELECT uniqThetaNot([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:45.301676 [ 32979 ] {2d1e16b0-2b6a-46ee-9bec-bd314474322d} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 1, should be 2: In scope SELECT uniqThetaUnion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1559, line 1562) (in query: SELECT uniqThetaUnion([]);) 2025.07.13 02:39:45.304971 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 1, should be 2: In scope SELECT uniqThetaUnion([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:45.558760 [ 32979 ] {8d0dc9b5-fac1-43a2-a252-86e913bf4db9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function upper: In scope SELECT upper([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1561, line 1564) (in query: SELECT upper([]);) 2025.07.13 02:39:45.578604 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function upper: In scope SELECT upper([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:45.733523 [ 32979 ] {17df427d-7ac1-4445-b92e-74ca6206fefc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function upperUTF8: In scope SELECT upperUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1562, line 1565) (in query: SELECT upperUTF8([]);) 2025.07.13 02:39:45.741890 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function upperUTF8: In scope SELECT upperUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:45.780479 [ 32979 ] {4eb2b5a3-21b4-4536-a82c-538f412d28f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 1, should be 0: In scope SELECT uptime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1563, line 1566) (in query: SELECT uptime([]);) 2025.07.13 02:39:45.784607 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 1, should be 0: In scope SELECT uptime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:45.817838 [ 32979 ] {19ca299d-3d9f-4ac1-91d8-d9816887d9c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT user([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1564, line 1567) (in query: SELECT user([]);) 2025.07.13 02:39:45.823008 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT user([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:45.850845 [ 32979 ] {099fd9d9-7da9-4aeb-b87c-a19c0aafb672} executeQuery: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 1.: In scope SELECT validateNestedArraySizes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1565, line 1568) (in query: SELECT validateNestedArraySizes([]);) 2025.07.13 02:39:45.855145 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 1.: In scope SELECT validateNestedArraySizes([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:45.893725 [ 32979 ] {f0ac6752-105f-4715-98c9-901047e28adb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1566, line 1569) (in query: SELECT varPop([]);) 2025.07.13 02:39:45.991924 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:46.053962 [ 32979 ] {3fd226be-5f12-477c-bed7-7c76c66c99a3} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1567, line 1570) (in query: SELECT varPopStable([]);) 2025.07.13 02:39:46.058203 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.07.13 02:39:46.080672 [ 32979 ] {c12176fe-8288-4fed-9e2f-674447572218} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1568, line 1571) (in query: SELECT varSamp([]);) 2025.07.13 02:39:46.084880 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function varSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:46.131799 [ 32979 ] {cec4c8bd-fa3e-493c-be89-0be3680ee14e} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1569, line 1572) (in query: SELECT varSampStable([]);) 2025.07.13 02:39:46.135972 [ 32979 ] {} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.07.13 02:39:46.167830 [ 32979 ] {19b1f781-4f0e-41d2-8a04-71b8efb2b584} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 1, should be 2 or 3: In scope SELECT variantElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1570, line 1573) (in query: SELECT variantElement([]);) 2025.07.13 02:39:46.172833 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 1, should be 2 or 3: In scope SELECT variantElement([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.269093 [ 32979 ] {e17af479-d0a2-41f8-89d9-fd4e1d8c69d7} executeQuery: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Array(Nothing) instead: In scope SELECT variantType([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1571, line 1574) (in query: SELECT variantType([]);) 2025.07.13 02:39:46.288016 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Array(Nothing) instead: In scope SELECT variantType([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:46.318700 [ 32979 ] {4b324826-f1c9-4ee4-a27a-31732ee0dc77} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT vectorDifference([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1572, line 1575) (in query: SELECT vectorDifference([]);) 2025.07.13 02:39:46.324254 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT vectorDifference([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.363065 [ 32979 ] {33f9944e-1976-4fa3-9e00-e91903a1efdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT vectorSum([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1573, line 1576) (in query: SELECT vectorSum([]);) 2025.07.13 02:39:46.367590 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT vectorSum([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.402512 [ 32979 ] {10348729-f6e2-4b94-9cbd-a5eb5ff63ec2} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 1, should be 0: In scope SELECT version([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1574, line 1577) (in query: SELECT version([]);) 2025.07.13 02:39:46.407432 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 1, should be 0: In scope SELECT version([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.579156 [ 32979 ] {b3b22fc4-f626-4275-b89f-23465aff6e59} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractBool([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1576, line 1579) (in query: SELECT visitParamExtractBool([]);) 2025.07.13 02:39:46.583439 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractBool([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.616265 [ 32979 ] {45bc87ff-5eec-4575-951e-d82ba1b7fb23} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractFloat([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1577, line 1580) (in query: SELECT visitParamExtractFloat([]);) 2025.07.13 02:39:46.619059 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractFloat([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.703852 [ 32979 ] {1424ddde-0a51-4340-9136-032c7fa7de4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1578, line 1581) (in query: SELECT visitParamExtractInt([]);) 2025.07.13 02:39:46.790927 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.824357 [ 32979 ] {83b7fb95-32a8-40e7-b8aa-427b90e43dc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractRaw([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1579, line 1582) (in query: SELECT visitParamExtractRaw([]);) 2025.07.13 02:39:46.832061 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractRaw([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.885645 [ 32979 ] {8ba1bd68-9426-49e8-8799-d982bc36a897} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1580, line 1583) (in query: SELECT visitParamExtractString([]);) 2025.07.13 02:39:46.896650 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractString([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:46.970450 [ 32979 ] {907d0a29-0805-4825-89c1-08c562c6f12e} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractUInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1581, line 1584) (in query: SELECT visitParamExtractUInt([]);) 2025.07.13 02:39:46.981988 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractUInt([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.021724 [ 32979 ] {60e99f5f-2a1f-47f2-853f-51f3d95a5ac0} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT visitParamHas([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1582, line 1585) (in query: SELECT visitParamHas([]);) 2025.07.13 02:39:47.081998 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT visitParamHas([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.248927 [ 32979 ] {0bba564e-33e7-433f-9671-c2eaa96ca044} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT week([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1583, line 1586) (in query: SELECT week([]);) 2025.07.13 02:39:47.251781 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT week([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:47.267430 [ 32979 ] {9b80c13a-90e5-447a-a20b-5fb6cc19bbd7} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1584, line 1587) (in query: SELECT welchTTest([]);) 2025.07.13 02:39:47.271258 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.363764 [ 32979 ] {3029554d-d21f-4129-9aef-54011ec38c1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT widthBucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1585, line 1588) (in query: SELECT widthBucket([]);) 2025.07.13 02:39:47.381036 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT widthBucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.460281 [ 32979 ] {18f229e8-9ef3-4437-907b-3c5df78fd4b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT width_bucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1586, line 1589) (in query: SELECT width_bucket([]);) 2025.07.13 02:39:47.464958 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT width_bucket([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.484924 [ 32979 ] {21f49b5d-16a9-4187-9722-aac02d5f011d} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1587, line 1590) (in query: SELECT windowFunnel([]);) 2025.07.13 02:39:47.488008 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.548985 [ 32979 ] {17740cb2-899d-4ec2-8b53-24fec773b159} executeQuery: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT windowID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1588, line 1591) (in query: SELECT windowID([]);) 2025.07.13 02:39:47.554190 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT windowID([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:47.595186 [ 32979 ] {f2879a37-a886-4ecd-b68b-732c9559114f} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT wkt([]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1589, line 1592) (in query: SELECT wkt([]);) 2025.07.13 02:39:47.600843 [ 32979 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT wkt([]). (BAD_ARGUMENTS) 2025.07.13 02:39:47.633026 [ 32979 ] {d3d2abb7-c398-455c-9088-211d71ccd245} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nothing): In scope SELECT wordShingleMinHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1590, line 1593) (in query: SELECT wordShingleMinHash([]);) 2025.07.13 02:39:47.638655 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nothing): In scope SELECT wordShingleMinHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:47.687216 [ 32979 ] {0faf4fcb-561b-4359-beb2-637e820be0d9} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArg([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1591, line 1594) (in query: SELECT wordShingleMinHashArg([]);) 2025.07.13 02:39:47.701933 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArg([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:47.731633 [ 32979 ] {12f38004-6bb8-42e6-9c91-e07a3e93ea87} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1592, line 1595) (in query: SELECT wordShingleMinHashArgCaseInsensitive([]);) 2025.07.13 02:39:47.737317 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:47.809346 [ 32979 ] {4554320d-38e6-4735-95a9-548d384fa6b0} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1593, line 1596) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8([]);) 2025.07.13 02:39:47.812349 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:47.840119 [ 32979 ] {e45ef502-f5db-4e00-a87f-8c2fc899742b} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1594, line 1597) (in query: SELECT wordShingleMinHashArgUTF8([]);) 2025.07.13 02:39:47.845417 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:47.910701 [ 32979 ] {9922d4ef-0c3d-4bd4-aa37-93e4f291edf4} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1595, line 1598) (in query: SELECT wordShingleMinHashCaseInsensitive([]);) 2025.07.13 02:39:47.918213 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.044117 [ 32979 ] {7fafbbb4-4778-4891-8948-ba9e83affe27} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1596, line 1599) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8([]);) 2025.07.13 02:39:48.049721 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.089085 [ 32979 ] {d1337196-6d0e-42b8-93bf-ffca27974b59} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1597, line 1600) (in query: SELECT wordShingleMinHashUTF8([]);) 2025.07.13 02:39:48.109816 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.156798 [ 32979 ] {e567f89d-b736-4a7a-abdf-32246349bbf1} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nothing): In scope SELECT wordShingleSimHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1598, line 1601) (in query: SELECT wordShingleSimHash([]);) 2025.07.13 02:39:48.168744 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nothing): In scope SELECT wordShingleSimHash([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.213681 [ 32979 ] {ea1ffdd4-d97b-424b-b6aa-ea3dd506c1eb} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1599, line 1602) (in query: SELECT wordShingleSimHashCaseInsensitive([]);) 2025.07.13 02:39:48.218364 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitive([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.246615 [ 32979 ] {fd57b1a1-752f-428c-bdea-018f242f72c0} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1600, line 1603) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8([]);) 2025.07.13 02:39:48.251568 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.306887 [ 32979 ] {920ab47e-b862-4752-8914-35c6bc7b6a14} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1601, line 1604) (in query: SELECT wordShingleSimHashUTF8([]);) 2025.07.13 02:39:48.312337 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashUTF8([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.419722 [ 32979 ] {918c9c75-1573-40e1-8e9a-7f72b0d84367} executeQuery: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 1: In scope SELECT xor([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1603, line 1606) (in query: SELECT xor([]);) 2025.07.13 02:39:48.427387 [ 32979 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 1: In scope SELECT xor([]). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.07.13 02:39:48.788280 [ 32979 ] {4a2022c9-b770-45e4-b206-639fb028f9e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT yandexConsistentHash([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1607, line 1610) (in query: SELECT yandexConsistentHash([]);) 2025.07.13 02:39:48.791284 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT yandexConsistentHash([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:48.809432 [ 32979 ] {b95c9587-69bc-43a7-88a8-cc96f9fb69a4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT yearweek([]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1608, line 1611) (in query: SELECT yearweek([]);) 2025.07.13 02:39:48.813951 [ 32979 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT yearweek([]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.13 02:39:48.848429 [ 32979 ] {a0108aa0-5fc1-4a07-9e5c-6ea816d5ece0} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 1, should be 0: In scope SELECT yesterday([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1609, line 1612) (in query: SELECT yesterday([]);) 2025.07.13 02:39:48.861205 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 1, should be 0: In scope SELECT yesterday([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:48.893126 [ 32979 ] {35b88113-36f9-4d1d-8d75-dd7e10fe47fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 1, should be 0: In scope SELECT zookeeperSessionUptime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59646) (comment: 00534_functions_bad_arguments4_long.sh) (query 1610, line 1613) (in query: SELECT zookeeperSessionUptime([]);) 2025.07.13 02:39:48.904273 [ 32979 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 1, should be 0: In scope SELECT zookeeperSessionUptime([]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.07.13 02:39:55.577415 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:41:02.154294 [ 73230 ] {3a1548de-1167-4304-84e8-7004fb71e0c3} executeQuery: Code: 60. DB::Exception: Table test_3ka5zlz3.test_replicated does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53118) (comment: 02676_optimize_old_parts_replicated.sh) (query 3, line 5) (in query: DROP TABLE test_replicated;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:41:02.170671 [ 73230 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3ka5zlz3.test_replicated does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbf0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7e4ea3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5f579e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5fc4f6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0c4a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:41:03.297628 [ 73230 ] {33bf3be8-c67a-4521-8e13-1c4b286a226e} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_replicated_limit (ee3b1611-235a-4c2d-92bc-da2b5a6fd08d)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44208) (comment: 02676_optimize_old_parts_replicated.sh) (query 3, line 7) (in query: INSERT INTO test_replicated_limit SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d56 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:41:03.300541 [ 73230 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_replicated_limit (ee3b1611-235a-4c2d-92bc-da2b5a6fd08d)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dcf0d56 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 15. ? @ 0x00007f9c53164ac3 16. ? @ 0x00007f9c531f6850 2025.07.13 02:41:13.027403 [ 73230 ] {62630fb4-1b95-4d81-9a9c-64487ff30da9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58642) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 1) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_replicated_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:41:13.042367 [ 73230 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:41:35.623321 [ 5380 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beb96ef 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb8d3c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beb7b36 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002beb7fce 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d493f2c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d49485f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bf297 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 17. ? @ 0x00007f9c53164ac3 18. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:42:43.076693 [ 2827 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5818 similar messages) 2025.07.13 02:43:00.445227 [ 73230 ] {5c612fed-6d9d-4064-8f79-d2f74ccd4e9c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45678) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 1) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_replicated_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:43:00.487115 [ 73230 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x0000000031825552 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000318232d1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822d8a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:43:21.724982 [ 73230 ] {a8e8d5e4-9b35-441d-ada3-772be41b9868} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_replicated_limit (ee3b1611-235a-4c2d-92bc-da2b5a6fd08d)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43014) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 2) (in query: DROP TABLE test_replicated_limit SYNC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:43:21.735197 [ 73230 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_replicated_limit (ee3b1611-235a-4c2d-92bc-da2b5a6fd08d)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dcaff1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaeb99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e2a80db 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316ad3fc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 18. ? @ 0x00007f9c53164ac3 19. ? @ 0x00007f9c531f6850 2025.07.13 02:43:28.787954 [ 3467 ] {857dc706-20a9-498f-8bf6-13bc49f65cfc::202507_1_241_48} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:43:28.789677 [ 3467 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {857dc706-20a9-498f-8bf6-13bc49f65cfc::202507_1_241_48}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bcaa5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc36c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc3496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030f075c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030f02cf1 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030f02ac7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f326d3 11. ./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&&) @ 0x0000000030dd2141 12. ./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 @ 0x0000000030dcc68b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f78c21 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f787cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f6ce21 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f775be 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f770b8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f76f05 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: 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) @ 0x0000000030f70991 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f7427d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003211e43f 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216d67a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c1fcf8 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c1204e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c23277 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c31709 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000031238a1c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:44:35.823051 [ 3463 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b74b8fb6-05a5-4d81-8ac8-db6cbf43b2a7::202507_153_219_45}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:45:40.088391 [ 5380 ] {91d47be2-7c4a-46c6-84b6-4d0ff1afd57a} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_replicated_limit (ee3b1611-235a-4c2d-92bc-da2b5a6fd08d)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39900) (comment: 02676_optimize_old_parts_replicated.sh) (in query: DROP DATABASE IF EXISTS test_3ka5zlz3 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 2025.07.13 02:45:40.090978 [ 5380 ] {91d47be2-7c4a-46c6-84b6-4d0ff1afd57a} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3ka5zlz3.test_replicated_limit (ee3b1611-235a-4c2d-92bc-da2b5a6fd08d)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd4d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc5b755 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dcb0e69 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcb71ef 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dcb01b9 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dcaf035 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dcae578 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 20. ? @ 0x00007f9c53164ac3 21. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:46:21.680962 [ 3463 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b74b8fb6-05a5-4d81-8ac8-db6cbf43b2a7::202507_153_230_56}: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab67af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab2fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003123a64b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x00000000312389c4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c729fd 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c73734 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc1b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bca474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 14. ? @ 0x00007f9c53164ac3 15. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:47:16.751375 [ 77976 ] {70904956-5555-4262-afc2-1207b4880c01} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60026.247047 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57690) (query 1, line 2) (in query: SELECT sleepEachRow(( SELECT maxOrDefault(300 - elapsed) + 1 FROM system.processes WHERE query NOT LIKE '%FROM system.processes%' AND elapsed < 300 ) / 300) FROM numbers(300) FORMAT Null SETTINGS function_sleep_max_microseconds_per_block = 0 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:47:16.751785 [ 77976 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60026.247047 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3bd7af 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3bcb9e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002def3f30 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x000000003182323d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x00000000318234b9 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031822fe5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003183dc97 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbed4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc69ea 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adc963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbe1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc0390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc0ad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003183c60d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183ccfd 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316c1f65 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316ad639 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316dcc6e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 13. ? @ 0x00007f9c53164ac3 14. ? @ 0x00007f9c531f6850 2025.07.13 02:47:17.289521 [ 5380 ] {71cc7534-68a1-4b1a-b579-dd17f8cb812d} executeQuery: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60870) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000002c710cda 5. ./build_docker/./src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x000000002c710a91 6. ./build_docker/./src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x000000002c710567 7. ./build_docker/./src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x000000002c948eb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc6079f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 2025.07.13 02:47:17.289933 [ 5380 ] {71cc7534-68a1-4b1a-b579-dd17f8cb812d} DynamicQueryHandler: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000002c710cda 5. ./build_docker/./src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x000000002c710a91 6. ./build_docker/./src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x000000002c710567 7. ./build_docker/./src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x000000002c948eb7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc6079f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc94de6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2ae194 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2b3bb0 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315bff47 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315c572b 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316f1b0c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035aca8c2 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035acb592 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a342f7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a2fcee 19. ? @ 0x00007f9c53164ac3 20. ? @ 0x00007f9c531f6850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:47:20.987161 [ 2820 ] {} Application: Closed all listening sockets. Waiting for 38 outstanding connections. 2025.07.13 02:47:25.893159 [ 2820 ] {} Application: Closed connections. But 38 remain. Tip: To increase wait time add to config: 60 2025.07.13 02:47:25.893225 [ 2820 ] {} Application: Will shutdown forcefully. 2025.07.13 02:47:27.543316 [ 78069 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.07.13 02:47:27.869043 [ 78075 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 02:47:28.001926 [ 78069 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.13 02:47:28.003655 [ 78069 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 02:47:28.003666 [ 78069 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 02:47:28.054421 [ 78654 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 02:47:28.234902 [ 78069 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.07.13 02:47:28.235265 [ 78069 ] {} 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.13 02:47:28.235555 [ 78069 ] {} 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.13 02:47:37.769659 [ 78895 ] {} system.query_metric_log (9c26bd11-e33e-4caf-9c46-d10192a9d6d0): Removing temporary directory /var/lib/clickhouse/store/9c2/9c26bd11-e33e-4caf-9c46-d10192a9d6d0/tmp_merge_202507_1_186_37/ 2025.07.13 02:47:39.474650 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_5svdfxnj.sql.tmp 2025.07.13 02:47:39.474720 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_78e6x9uo.sql.tmp 2025.07.13 02:47:39.474761 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_0bnt8kdp.sql.tmp 2025.07.13 02:47:39.474803 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_wri6s91d.sql.tmp 2025.07.13 02:47:39.474844 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_5pg7c564.sql.tmp 2025.07.13 02:47:39.474891 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_xqe7rxuc.sql.tmp 2025.07.13 02:47:39.474951 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_mhtll780.sql.tmp 2025.07.13 02:47:39.474986 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_9bm2ubw1.sql.tmp 2025.07.13 02:47:39.475026 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_nr2eoj9z.sql.tmp 2025.07.13 02:47:39.475078 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_t707dwde.sql.tmp 2025.07.13 02:47:39.475113 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_nq89i1q6.sql.tmp 2025.07.13 02:47:39.475148 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_0pa8bzvy.sql.tmp 2025.07.13 02:47:39.475182 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_2bit7vhs.sql.tmp 2025.07.13 02:47:39.475219 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_n15zob3k.sql.tmp 2025.07.13 02:47:39.475258 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_ym8grnne.sql.tmp 2025.07.13 02:47:39.475305 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_wjn8pmdz.sql.tmp 2025.07.13 02:47:39.475341 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_de2gw0u6.sql.tmp 2025.07.13 02:47:39.475373 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_kwy4gwzi.sql.tmp 2025.07.13 02:47:39.475415 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_5f730a7o.sql.tmp 2025.07.13 02:47:39.475461 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_uoyd9xxf.sql.tmp 2025.07.13 02:47:39.475496 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_3xfw6rcc.sql.tmp 2025.07.13 02:47:39.475547 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_kzq34uft.sql.tmp 2025.07.13 02:47:39.475583 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_x310t2ik.sql.tmp 2025.07.13 02:47:39.475656 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_duf4jjsn.sql.tmp 2025.07.13 02:47:39.475698 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_1tkc503c.sql.tmp 2025.07.13 02:47:39.475740 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_nuse82ur.sql.tmp 2025.07.13 02:47:39.475774 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_el6xky45.sql.tmp 2025.07.13 02:47:39.475831 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_luxhjbn4.sql.tmp 2025.07.13 02:47:39.475869 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_0pkagdbw.sql.tmp 2025.07.13 02:47:39.475905 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_3onrropy.sql.tmp 2025.07.13 02:47:39.475988 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_aih27lub.sql.tmp 2025.07.13 02:47:39.476021 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_7j379qjr.sql.tmp 2025.07.13 02:47:39.476064 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_ty7dv1qt.sql.tmp 2025.07.13 02:47:39.476102 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_onmuqdfy.sql.tmp 2025.07.13 02:47:39.476135 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_k4bhldg8.sql.tmp 2025.07.13 02:47:39.476169 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_vonzcqq5.sql.tmp 2025.07.13 02:47:39.476218 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_u2no15pk.sql.tmp 2025.07.13 02:47:39.476250 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_psclrank.sql.tmp 2025.07.13 02:47:39.476281 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_ra2m2or5.sql.tmp 2025.07.13 02:47:39.476319 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_ynptwpbp.sql.tmp 2025.07.13 02:47:39.476376 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_lg2n33yj.sql.tmp 2025.07.13 02:47:39.476409 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_flc8znqr.sql.tmp 2025.07.13 02:47:39.476441 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_6d1gsjlc.sql.tmp 2025.07.13 02:47:39.476489 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_onlg19qc.sql.tmp 2025.07.13 02:47:39.476527 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_85hfbwtu.sql.tmp 2025.07.13 02:47:39.476560 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_khlb6pq5.sql.tmp 2025.07.13 02:47:39.476594 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_xj24mv3i.sql.tmp 2025.07.13 02:47:39.476664 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_c4z02pyy.sql.tmp 2025.07.13 02:47:39.476702 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_yzcdnuv3.sql.tmp 2025.07.13 02:47:39.476749 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_hk2ufqnk.sql.tmp 2025.07.13 02:47:39.476804 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_l0n5cyzl.sql.tmp 2025.07.13 02:47:39.476839 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_jt8vun87.sql.tmp 2025.07.13 02:47:39.476942 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_cacs3gos.sql.tmp 2025.07.13 02:47:39.476992 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_m7t5pmhi.sql.tmp 2025.07.13 02:47:39.477034 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_1tl7t4kw.sql.tmp 2025.07.13 02:47:39.477081 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_a2aht1xk.sql.tmp 2025.07.13 02:47:39.477118 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_rr5ali8a.sql.tmp 2025.07.13 02:47:39.477162 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_nnlskhxr.sql.tmp 2025.07.13 02:47:39.477198 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_qco7tovu.sql.tmp 2025.07.13 02:47:39.477229 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_uqsslrog.sql.tmp 2025.07.13 02:47:39.477269 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_9rwvqoal.sql.tmp 2025.07.13 02:47:39.477302 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_rdblex9s.sql.tmp 2025.07.13 02:47:39.477361 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_guzwf4s0.sql.tmp 2025.07.13 02:47:39.477397 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_cclexy94.sql.tmp 2025.07.13 02:47:39.477428 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_q5zr37ig.sql.tmp 2025.07.13 02:47:39.477458 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_qezhp1ya.sql.tmp 2025.07.13 02:47:39.477492 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_0fgp616o.sql.tmp 2025.07.13 02:47:39.477520 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_r7w32klu.sql.tmp 2025.07.13 02:47:39.477550 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_oztiy9r9.sql.tmp 2025.07.13 02:47:39.477583 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_loho3qa5.sql.tmp 2025.07.13 02:47:39.477611 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_alm2t9e1.sql.tmp 2025.07.13 02:47:39.477645 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_usuw1mqq.sql.tmp 2025.07.13 02:47:39.477682 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_878b1dgz.sql.tmp 2025.07.13 02:47:39.477719 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_czqzjxl8.sql.tmp 2025.07.13 02:47:39.477755 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_a9k7fn2v.sql.tmp 2025.07.13 02:47:39.477791 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_60btgujd.sql.tmp 2025.07.13 02:47:39.477821 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_qw3rkqn5.sql.tmp 2025.07.13 02:47:39.477849 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_9vrunrn5.sql.tmp 2025.07.13 02:47:39.477884 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_1n7jioh0.sql.tmp 2025.07.13 02:47:39.477914 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_rxljzuad.sql.tmp 2025.07.13 02:47:39.477944 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_y3n76i4r.sql.tmp 2025.07.13 02:47:39.477979 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_pwj28o3e.sql.tmp 2025.07.13 02:47:39.478009 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_lj170dth.sql.tmp 2025.07.13 02:47:39.478039 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_h1nylpzb.sql.tmp 2025.07.13 02:47:39.478079 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_6q6ww3gs.sql.tmp 2025.07.13 02:47:39.478116 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test.sql.tmp 2025.07.13 02:47:39.478144 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_9zmep1ff.sql.tmp 2025.07.13 02:47:39.478180 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_0czk34fb.sql.tmp 2025.07.13 02:47:39.478212 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_ztmabonp.sql.tmp 2025.07.13 02:47:39.478244 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_7fvibype.sql.tmp 2025.07.13 02:47:39.478279 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_7z6jq8q7.sql.tmp 2025.07.13 02:47:39.478324 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_nz8b5qko.sql.tmp 2025.07.13 02:47:39.478355 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_8fwl5gba.sql.tmp 2025.07.13 02:47:39.478384 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_45h90s9f.sql.tmp 2025.07.13 02:47:39.478412 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_3co8x4ol.sql.tmp 2025.07.13 02:47:39.478442 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_hqvebohm.sql.tmp 2025.07.13 02:47:39.478471 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_lgesmsfe.sql.tmp 2025.07.13 02:47:39.478500 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_pa7lyi6c.sql.tmp 2025.07.13 02:47:39.478528 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_kddkpc5v.sql.tmp 2025.07.13 02:47:39.478557 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_vaotctb2.sql.tmp 2025.07.13 02:47:39.478590 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_e8ryabw0.sql.tmp 2025.07.13 02:47:39.478620 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_5pkzsfsb.sql.tmp 2025.07.13 02:47:39.478659 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_2qp5dhqd.sql.tmp 2025.07.13 02:47:39.478689 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_lp0zrc12.sql.tmp 2025.07.13 02:47:39.478718 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_zcxzjasp.sql.tmp 2025.07.13 02:47:39.478751 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_tg72mgca.sql.tmp 2025.07.13 02:47:39.478780 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_kzw3vfrv.sql.tmp 2025.07.13 02:47:39.478810 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_l2x5o5wp.sql.tmp 2025.07.13 02:47:39.478838 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_2pc72l6u.sql.tmp 2025.07.13 02:47:39.478874 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_0uif26ko.sql.tmp 2025.07.13 02:47:39.478908 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_nlvlfp6h.sql.tmp 2025.07.13 02:47:39.478943 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_i5pns5s2.sql.tmp 2025.07.13 02:47:39.478977 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_2i6qa7zg.sql.tmp 2025.07.13 02:47:39.479006 [ 78069 ] {} loadMetadata: Removing temporary file metadata/test_zg21ge6m.sql.tmp 2025.07.13 02:47:39.537248 [ 78069 ] {} DatabaseReplicated (test_j87ppvms): Database test_j87ppvms exists locally, but its replica does not exist in ZooKeeper (/test/db/test_2/replicas/s1|r1). Assuming it was dropped, will not try to start it up 2025.07.13 02:47:39.550693 [ 78069 ] {} TablesLoader: Tables test_adhu7tze.hashed_array_dictionary_complex_key_simple_attributes depend on test_adhu7tze.complex_key_simple_attributes_source_table, but seems like that does not exist. Will ignore it and try to load existing tables 2025.07.13 02:47:39.550907 [ 78069 ] {} TablesLoader: Tables test_11.dist_layer_01319 depend on default.sub_key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.07.13 02:47:39.550938 [ 78069 ] {} TablesLoader: Tables test_11.dict2 depend on test_11.datetime_table, but seems like that does not exist. Will ignore it and try to load existing tables 2025.07.13 02:47:39.590810 [ 78917 ] {} test_7.table_two (4ca412a9-e2eb-49ee-8019-b646c94a69a5): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:47:39.601244 [ 78870 ] {} test_7.mt_compact (978a2d2a-86ad-4be8-9c56-cc17a02e4187): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 10485760. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:47:39.822637 [ 78864 ] {} test_9.table_one (ba9792e2-3a6b-4f83-8ef9-af0faea25711): Table can't create parts with adaptive granularity, but settings min_rows_for_wide_part = 0, min_bytes_for_wide_part = 100. Parts with non-adaptive granularity can be stored only in Wide (default) format. Settings 'min_rows_for_wide_part'and 'min_bytes_for_wide_part' will be ignored. 2025.07.13 02:47:58.466963 [ 79227 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.07.13 02:47:58.564217 [ 79227 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f251d5bcd90 30. ? @ 0x00007f251d5bce40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:47:58.564553 [ 79227 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.07.13 02:47:58.564599 [ 79227 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f251d5bcd90 30. ? @ 0x00007f251d5bce40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:47:58.564715 [ 79227 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.07.13 02:47:58.564748 [ 79227 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f251d5bcd90 30. ? @ 0x00007f251d5bce40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:47:58.564853 [ 79227 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.07.13 02:47:58.564885 [ 79227 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f251d5bcd90 30. ? @ 0x00007f251d5bce40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:15.445913 [ 79931 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.07.13 02:48:15.549741 [ 79931 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f0f72f3dd90 30. ? @ 0x00007f0f72f3de40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:15.550031 [ 79931 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.07.13 02:48:15.550071 [ 79931 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f0f72f3dd90 30. ? @ 0x00007f0f72f3de40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:15.550182 [ 79931 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.07.13 02:48:15.550213 [ 79931 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f0f72f3dd90 30. ? @ 0x00007f0f72f3de40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:15.550326 [ 79931 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.07.13 02:48:15.550357 [ 79931 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007f0f72f3dd90 30. ? @ 0x00007f0f72f3de40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:31.199730 [ 80617 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.07.13 02:48:31.295748 [ 80617 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007eff8a9ded90 30. ? @ 0x00007eff8a9dee40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:31.296080 [ 80617 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.07.13 02:48:31.296123 [ 80617 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007eff8a9ded90 30. ? @ 0x00007eff8a9dee40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:31.296335 [ 80617 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.07.13 02:48:31.296368 [ 80617 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007eff8a9ded90 30. ? @ 0x00007eff8a9dee40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:48:31.296478 [ 80617 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.07.13 02:48:31.296509 [ 80617 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ca94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x00000000359a0440 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e46cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cc02f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b11560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1145e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1b868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c955552 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c9574d6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c965d62 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c9584a2 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c941ceb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9419dc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9808cc 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4af35b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4af936 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4b0522 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47b88d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7d0cdc 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c71c983 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d617e81 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d617c5f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d617a86 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5f1835 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4ee44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e47517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b14dbb 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e5a9b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb2ba8 29. ? @ 0x00007eff8a9ded90 30. ? @ 0x00007eff8a9dee40 31. _start @ 0x0000000017c9802e (version 25.3.3.20372.altinityantalya (altinity build))